diff --git a/azure-batch/HISTORY.rst b/azure-batch/HISTORY.rst index 7569d686b5e9..3f138ed59c91 100644 --- a/azure-batch/HISTORY.rst +++ b/azure-batch/HISTORY.rst @@ -3,6 +3,15 @@ Release History =============== +5.1.0 (2018-08-28) +++++++++++++++++++ + +- Update operation TaskOperations.add_collection with the following added functionality: + - Retry server side errors. + - Automatically chunk lists of more than 100 tasks to multiple requests. + - If tasks are too large to be submitted in chunks of 100, reduces number of tasks per request. + - Add a parameter to specify number of threads to use when submitting tasks. + 5.0.0 (2018-08-24) ++++++++++++++++++ diff --git a/azure-batch/azure/batch/batch_service_client.py b/azure-batch/azure/batch/batch_service_client.py index 80c19929f9cb..b581445ac430 100644 --- a/azure-batch/azure/batch/batch_service_client.py +++ b/azure-batch/azure/batch/batch_service_client.py @@ -23,6 +23,7 @@ from .operations.task_operations import TaskOperations from .operations.compute_node_operations import ComputeNodeOperations from . import models +from .custom.patch import patch_client class BatchServiceClientConfiguration(AzureConfiguration): @@ -112,3 +113,5 @@ def __init__( self._client, self.config, self._serialize, self._deserialize) self.compute_node = ComputeNodeOperations( self._client, self.config, self._serialize, self._deserialize) + + patch_client(self) diff --git a/azure-batch/azure/batch/custom/__init__.py b/azure-batch/azure/batch/custom/__init__.py new file mode 100644 index 000000000000..e69de29bb2d1 diff --git a/azure-batch/azure/batch/custom/custom_errors.py b/azure-batch/azure/batch/custom/custom_errors.py new file mode 100644 index 000000000000..17da723515f3 --- /dev/null +++ b/azure-batch/azure/batch/custom/custom_errors.py @@ -0,0 +1,19 @@ +# -------------------------------------------------------------------------------------------- +# Copyright (c) Microsoft Corporation. All rights reserved. +# Licensed under the MIT License. See License.txt in the project root for license information. +# -------------------------------------------------------------------------------------------- + + +class CreateTasksErrorException(Exception): + """ Aggregate Exception containing details for any failures from a task add operation. + + :param str message: Error message describing exit reason + :param [~TaskAddParameter] pending_task_list: List of tasks remaining to be submitted. + :param [~TaskAddResult] failure_tasks: List of tasks which failed to add + :param [~Exception] errors: List of unknown errors forcing early termination + """ + def __init__(self, message, pending_task_list=None, failure_tasks=None, errors=None): + self.message = message + self.pending_tasks = list(pending_task_list) + self.failure_tasks = list(failure_tasks) + self.errors = list(errors) diff --git a/azure-batch/azure/batch/custom/patch.py b/azure-batch/azure/batch/custom/patch.py new file mode 100644 index 000000000000..dc1bf8fb2525 --- /dev/null +++ b/azure-batch/azure/batch/custom/patch.py @@ -0,0 +1,296 @@ +import collections +import importlib +import logging +import threading +import types +import sys + +from ..models import BatchErrorException, TaskAddCollectionResult, TaskAddStatus +from ..custom.custom_errors import CreateTasksErrorException +from ..operations.task_operations import TaskOperations + +MAX_TASKS_PER_REQUEST = 100 +_LOGGER = logging.getLogger(__name__) + +class _TaskWorkflowManager(object): + """Worker class for one add_collection request + + :param ~TaskOperations task_operations: Parent object which instantiated this + :param str job_id: The ID of the job to which the task collection is to be + added. + :param tasks_to_add: The collection of tasks to add. + :type tasks_to_add: list of :class:`TaskAddParameter + ` + :param task_add_collection_options: Additional parameters for the + operation + :type task_add_collection_options: :class:`TaskAddCollectionOptions + ` + :param dict custom_headers: headers that will be added to the request + :param bool raw: returns the direct response alongside the + deserialized response + """ + + def __init__( + self, + client, + job_id, + tasks_to_add, + task_add_collection_options=None, + custom_headers=None, + raw=False, + **kwargs): + # Append operations thread safe - Only read once all threads have completed + # List of tasks which failed to add due to a returned client error + self._failure_tasks = collections.deque() + # List of unknown exceptions which occurred during requests. + self._errors = collections.deque() + + # synchronized through lock variables + self.error = None # Only written once all threads have completed + self._max_tasks_per_request = MAX_TASKS_PER_REQUEST + self._tasks_to_add = collections.deque(tasks_to_add) + + self._error_lock = threading.Lock() + self._max_tasks_lock = threading.Lock() + self._pending_queue_lock = threading.Lock() + + # Variables to be used for task add_collection requests + self._client = TaskOperations( + client._client, client.config, client._serialize, client._deserialize) + self._job_id = job_id + self._task_add_collection_options = task_add_collection_options + self._custom_headers = custom_headers + self._raw = raw + self._kwargs = dict(**kwargs) + + def _bulk_add_tasks(self, results_queue, chunk_tasks_to_add): + """Adds a chunk of tasks to the job + + Retry chunk if body exceeds the maximum request size and retry tasks + if failed due to server errors. + + :param results_queue: Queue to place the return value of the request + :type results_queue: collections.deque + :param chunk_tasks_to_add: Chunk of at most 100 tasks with retry details + :type chunk_tasks_to_add: list[~TrackedCloudTask] + """ + + try: + add_collection_response = self._client.add_collection( + self._job_id, + chunk_tasks_to_add, + self._task_add_collection_options, + self._custom_headers, + self._raw) + except BatchErrorException as e: + # In case of a chunk exceeding the MaxMessageSize split chunk in half + # and resubmit smaller chunk requests + # TODO: Replace string with constant variable once available in SDK + if e.error.code == "RequestBodyTooLarge": # pylint: disable=no-member + # In this case the task is misbehaved and will not be able to be added due to: + # 1) The task exceeding the max message size + # 2) A single cell of the task exceeds the per-cell limit, or + # 3) Sum of all cells exceeds max row limit + if len(chunk_tasks_to_add) == 1: + failed_task = chunk_tasks_to_add.pop() + self._errors.appendleft(e) + _LOGGER.error("Failed to add task with ID %s due to the body" + " exceeding the maximum request size", failed_task.id) + else: + # Assumption: Tasks are relatively close in size therefore if one batch exceeds size limit + # we should decrease the initial task collection size to avoid repeating the error + # Midpoint is lower bounded by 1 due to above base case + midpoint = int(len(chunk_tasks_to_add) / 2) + # Restrict one thread at a time to do this compare and set, + # therefore forcing max_tasks_per_request to be strictly decreasing + with self._max_tasks_lock: + if midpoint < self._max_tasks_per_request: + self._max_tasks_per_request = midpoint + _LOGGER.info("Amount of tasks per request reduced from %s to %s due to the" + " request body being too large", str(self._max_tasks_per_request), + str(midpoint)) + + # Not the most efficient solution for all cases, but the goal of this is to handle this + # exception and have it work in all cases where tasks are well behaved + # Behavior retries as a smaller chunk and + # appends extra tasks to queue to be picked up by another thread . + self._tasks_to_add.extendleft(chunk_tasks_to_add[midpoint:]) + self._bulk_add_tasks(results_queue, chunk_tasks_to_add[:midpoint]) + # Retry server side errors + elif 500 <= e.response.status_code <= 599: + self._tasks_to_add.extendleft(chunk_tasks_to_add) + else: + # Re-add to pending queue as unknown status / don't have result + self._tasks_to_add.extendleft(chunk_tasks_to_add) + # Unknown State - don't know if tasks failed to add or were successful + self._errors.appendleft(e) + except Exception as e: # pylint: disable=broad-except + # Re-add to pending queue as unknown status / don't have result + self._tasks_to_add.extendleft(chunk_tasks_to_add) + # Unknown State - don't know if tasks failed to add or were successful + self._errors.appendleft(e) + else: + try: + add_collection_response = add_collection_response.output + except AttributeError: + pass + + for task_result in add_collection_response.value: # pylint: disable=no-member + if task_result.status == TaskAddStatus.server_error: + # Server error will be retried + with self._pending_queue_lock: + for task in chunk_tasks_to_add: + if task.id == task_result.task_id: + self._tasks_to_add.appendleft(task) + elif (task_result.status == TaskAddStatus.client_error + and not task_result.error.code == "TaskExists"): + # Client error will be recorded unless Task already exists + self._failure_tasks.appendleft(task_result) + else: + results_queue.appendleft(task_result) + + def task_collection_thread_handler(self, results_queue): + """Main method for worker to run + + Pops a chunk of tasks off the collection of pending tasks to be added and submits them to be added. + + :param collections.deque results_queue: Queue for worker to output results to + """ + # Add tasks until either we run out or we run into an unexpected error + while self._tasks_to_add and not self._errors: + max_tasks = self._max_tasks_per_request # local copy + chunk_tasks_to_add = [] + with self._pending_queue_lock: + while len(chunk_tasks_to_add) < max_tasks and self._tasks_to_add: + chunk_tasks_to_add.append(self._tasks_to_add.pop()) + + if chunk_tasks_to_add: + self._bulk_add_tasks(results_queue, chunk_tasks_to_add) + + # Only define error if all threads have finished and there were failures + with self._error_lock: + if threading.active_count() == 1 and (self._failure_tasks or self._errors): + self.error = CreateTasksErrorException( + "One or more tasks failed to be added", + self._failure_tasks, + self._tasks_to_add, + self._errors) + + +def _handle_output(results_queue): + """Scan output for exceptions + + If there is an output from an add task collection call add it to the results. + + :param results_queue: Queue containing results of attempted add_collection's + :type results_queue: collections.deque + :return: list of TaskAddResults + :rtype: list[~TaskAddResult] + """ + results = [] + while results_queue: + queue_item = results_queue.pop() + results.append(queue_item) + return results + +def patch_client(client): + try: + models = sys.modules['azure.batch.models'] + except KeyError: + models = importlib.import_module('azure.batch.models') + setattr(models, 'CreateTasksErrorException', CreateTasksErrorException) + sys.modules['azure.batch.models'] = models + client.task.add_collection = types.MethodType(bulk_add_collection, client.task) + +def bulk_add_collection( + client, + job_id, + value, + task_add_collection_options=None, + custom_headers=None, + raw=False, + threads=0, + **operation_config): + """Adds a collection of tasks to the specified job. + + Note that each task must have a unique ID. The Batch service may not + return the results for each task in the same order the tasks were + submitted in this request. If the server times out or the connection is + closed during the request, the request may have been partially or fully + processed, or not at all. In such cases, the user should re-issue the + request. Note that it is up to the user to correctly handle failures + when re-issuing a request. For example, you should use the same task + IDs during a retry so that if the prior operation succeeded, the retry + will not create extra tasks unexpectedly. If the response contains any + tasks which failed to add, a client can retry the request. In a retry, + it is most efficient to resubmit only tasks that failed to add, and to + omit tasks that were successfully added on the first attempt. The + maximum lifetime of a task from addition to completion is 7 days. If a + task has not completed within 7 days of being added it will be + terminated by the Batch service and left in whatever state it was in at + that time. + + :param job_id: The ID of the job to which the task collection is to be + added. + :type job_id: str + :param value: The collection of tasks to add. The total serialized + size of this collection must be less than 4MB. If it is greater than + 4MB (for example if each task has 100's of resource files or + environment variables), the request will fail with code + 'RequestBodyTooLarge' and should be retried again with fewer tasks. + :type value: list of :class:`TaskAddParameter + ` + :param task_add_collection_options: Additional parameters for the + operation + :type task_add_collection_options: :class:`TaskAddCollectionOptions + ` + :param dict custom_headers: headers that will be added to the request + :param bool raw: returns the direct response alongside the + deserialized response + :param int threads: number of threads to use in parallel when adding tasks. If specified + and greater than 0, will start additional threads to submit requests and wait for them to finish. + Otherwise will submit add_collection requests sequentially on main thread + :return: :class:`TaskAddCollectionResult + ` or + :class:`ClientRawResponse` if + raw=true + :rtype: :class:`TaskAddCollectionResult + ` or + :class:`ClientRawResponse` + :raises: + :class:`BatchErrorException` + """ + + results_queue = collections.deque() # deque operations(append/pop) are thread-safe + task_workflow_manager = _TaskWorkflowManager( + client, + job_id, + value, + task_add_collection_options, + custom_headers, + raw, + **operation_config) + + # multi-threaded behavior + if threads: + if threads < 0: + raise ValueError("Threads must be positive or 0") + + active_threads = [] + for i in range(threads): + active_threads.append(threading.Thread( + target=task_workflow_manager.task_collection_thread_handler, + args=(results_queue,))) + active_threads[-1].start() + for thread in active_threads: + thread.join() + # single-threaded behavior + else: + task_workflow_manager.task_collection_thread_handler(results_queue) + + if task_workflow_manager.error: + raise task_workflow_manager.error # pylint: disable=raising-bad-type + else: + submitted_tasks = _handle_output(results_queue) + return TaskAddCollectionResult(value=submitted_tasks) + bulk_add_collection.metadata = {'url': '/jobs/{jobId}/addtaskcollection'} diff --git a/azure-batch/azure/batch/version.py b/azure-batch/azure/batch/version.py index 654c55a24205..df536f4a0d45 100644 --- a/azure-batch/azure/batch/version.py +++ b/azure-batch/azure/batch/version.py @@ -9,5 +9,5 @@ # regenerated. # -------------------------------------------------------------------------- -VERSION = "5.0.0" +VERSION = "5.1.0" diff --git a/azure-batch/tests/recordings/test_batch.test_batch_tasks.yaml b/azure-batch/tests/recordings/test_batch.test_batch_tasks.yaml index 2a034712ab4a..f72f2c6b38e9 100644 --- a/azure-batch/tests/recordings/test_batch.test_batch_tasks.yaml +++ b/azure-batch/tests/recordings/test_batch.test_batch_tasks.yaml @@ -1,19 +1,19 @@ interactions: - request: - body: '{"id": "batch_task1_98da0af6", "exitConditions": {"exitCodes": [{"exitOptions": - {"jobAction": "terminate"}, "code": 1}], "default": {"jobAction": "none"}, "exitCodeRanges": - [{"exitOptions": {"jobAction": "disable"}, "start": 2, "end": 4}]}, "commandLine": - "cmd /c \"echo hello world\""}' + body: '{"id": "batch_task1_98da0af6", "commandLine": "cmd /c \"echo hello world\"", + "exitConditions": {"exitCodes": [{"code": 1, "exitOptions": {"jobAction": "terminate"}}], + "exitCodeRanges": [{"start": 2, "end": 4, "exitOptions": {"jobAction": "disable"}}], + "default": {"jobAction": "none"}}}' headers: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['286'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:10 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:13 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: @@ -21,11 +21,11 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:11 GMT'] - etag: ['0x8D609F4845DC881'] - last-modified: ['Fri, 24 Aug 2018 19:05:11 GMT'] + date: ['Thu, 13 Sep 2018 20:24:13 GMT'] + etag: ['0x8D619B6DF299ACC'] + last-modified: ['Thu, 13 Sep 2018 20:24:13 GMT'] location: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6'] - request-id: [b9126cc2-219f-440f-bce9-03fd511ffbf4] + request-id: [b598e238-ad4b-4809-8eae-a38eccb5cb8c] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -37,14 +37,14 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:11 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:13 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task1_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6\",\"eTag\":\"0x8D609F4845DC881\",\"creationTime\":\"2018-08-24T19:05:11.6912769Z\",\"lastModified\":\"2018-08-24T19:05:11.6912769Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:11.6912769Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task1_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6\",\"eTag\":\"0x8D619B6DF299ACC\",\"creationTime\":\"2018-09-13T20:24:13.8291916Z\",\"lastModified\":\"2018-09-13T20:24:13.8291916Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:13.8291916Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"exitConditions\":{\r\n \ \"exitCodes\":[\r\n {\r\n \"code\":1,\"exitOptions\":{\r\n @@ -56,33 +56,33 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:11 GMT'] - etag: ['0x8D609F4845DC881'] - last-modified: ['Fri, 24 Aug 2018 19:05:11 GMT'] - request-id: [1a0d5b95-78e1-49ed-9e74-26afd9462fe0] + date: ['Thu, 13 Sep 2018 20:24:14 GMT'] + etag: ['0x8D619B6DF299ACC'] + last-modified: ['Thu, 13 Sep 2018 20:24:13 GMT'] + request-id: [52be7545-389e-467e-a220-c391b3c77bbc] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] x-content-type-options: [nosniff] status: {code: 200, message: OK} - request: - body: '{"outputFiles": [{"uploadOptions": {"uploadCondition": "taskcompletion"}, - "filePattern": "../stdout.txt", "destination": {"container": {"containerUrl": - "https://test.blob.core.windows.net:443/test-container", "path": "taskLogs/output.txt"}}}, - {"uploadOptions": {"uploadCondition": "taskfailure"}, "filePattern": "../stderr.txt", - "destination": {"container": {"containerUrl": "https://test.blob.core.windows.net:443/test-container", - "path": "taskLogs/error.txt"}}}], "id": "batch_task2_98da0af6", "commandLine": - "cmd /c \"echo hello world\""}' + body: '{"id": "batch_task2_98da0af6", "commandLine": "cmd /c \"echo hello world\"", + "outputFiles": [{"filePattern": "../stdout.txt", "destination": {"container": + {"path": "taskLogs/output.txt", "containerUrl": "https://test.blob.core.windows.net:443/test-container"}}, + "uploadOptions": {"uploadCondition": "taskcompletion"}}, {"filePattern": "../stderr.txt", + "destination": {"container": {"path": "taskLogs/error.txt", "containerUrl": + "https://test.blob.core.windows.net:443/test-container"}}, "uploadOptions": + {"uploadCondition": "taskfailure"}}]}' headers: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['541'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:12 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:14 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: @@ -90,11 +90,11 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:13 GMT'] - etag: ['0x8D609F4857AAFDF'] - last-modified: ['Fri, 24 Aug 2018 19:05:13 GMT'] + date: ['Thu, 13 Sep 2018 20:24:14 GMT'] + etag: ['0x8D619B6E00C2310'] + last-modified: ['Thu, 13 Sep 2018 20:24:15 GMT'] location: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6'] - request-id: [c22396f4-6181-47f2-b41b-fd10ce0c3f0e] + request-id: [280f0faf-bc96-4870-bc66-8aab0b0a348b] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -106,14 +106,14 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:13 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:15 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task2_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6\",\"eTag\":\"0x8D609F4857AAFDF\",\"creationTime\":\"2018-08-24T19:05:13.5584223Z\",\"lastModified\":\"2018-08-24T19:05:13.5584223Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:13.5584223Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task2_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6\",\"eTag\":\"0x8D619B6E00C2310\",\"creationTime\":\"2018-09-13T20:24:15.3137936Z\",\"lastModified\":\"2018-09-13T20:24:15.3137936Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:15.3137936Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"outputFiles\":[\r\n {\r\n \"filePattern\":\"../stdout.txt\",\"destination\":{\r\n \ \"container\":{\r\n \"containerUrl\":\"https://test.blob.core.windows.net:443/test-container\",\"path\":\"taskLogs/output.txt\"\r\n \ }\r\n },\"uploadOptions\":{\r\n \"uploadCondition\":\"TaskCompletion\"\r\n @@ -126,28 +126,28 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:14 GMT'] - etag: ['0x8D609F4857AAFDF'] - last-modified: ['Fri, 24 Aug 2018 19:05:13 GMT'] - request-id: [4a090c55-2cd3-41b7-9fa3-c2addca8dcd7] + date: ['Thu, 13 Sep 2018 20:24:16 GMT'] + etag: ['0x8D619B6E00C2310'] + last-modified: ['Thu, 13 Sep 2018 20:24:15 GMT'] + request-id: [0a175a8b-0d20-4ed4-8da9-9de0c79b9658] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] x-content-type-options: [nosniff] status: {code: 200, message: OK} - request: - body: '{"userIdentity": {"autoUser": {"elevationLevel": "admin", "scope": "task"}}, - "id": "batch_task3_98da0af6", "commandLine": "cmd /c \"echo hello world\""}' + body: '{"id": "batch_task3_98da0af6", "commandLine": "cmd /c \"echo hello world\"", + "userIdentity": {"autoUser": {"scope": "task", "elevationLevel": "admin"}}}' headers: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['152'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:14 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:16 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: @@ -155,11 +155,11 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:14 GMT'] - etag: ['0x8D609F4867C422C'] - last-modified: ['Fri, 24 Aug 2018 19:05:15 GMT'] + date: ['Thu, 13 Sep 2018 20:24:16 GMT'] + etag: ['0x8D619B6E0E932B1'] + last-modified: ['Thu, 13 Sep 2018 20:24:16 GMT'] location: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6'] - request-id: [6d474cf6-d113-41c2-b1d6-353ca295d642] + request-id: [4f897b0a-5ba3-4f9b-8514-2f65fe449faf] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -171,14 +171,14 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:15 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:16 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task3_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6\",\"eTag\":\"0x8D609F4867C422C\",\"creationTime\":\"2018-08-24T19:05:15.2464428Z\",\"lastModified\":\"2018-08-24T19:05:15.2464428Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:15.2464428Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task3_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6\",\"eTag\":\"0x8D619B6E0E932B1\",\"creationTime\":\"2018-09-13T20:24:16.7625393Z\",\"lastModified\":\"2018-09-13T20:24:16.7625393Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:16.7625393Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"scope\":\"task\",\"elevationLevel\":\"admin\"\r\n }\r\n },\"constraints\":{\r\n \ \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n @@ -186,10 +186,10 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:15 GMT'] - etag: ['0x8D609F4867C422C'] - last-modified: ['Fri, 24 Aug 2018 19:05:15 GMT'] - request-id: [18732242-b5de-45d6-a3b1-5370633b8cea] + date: ['Thu, 13 Sep 2018 20:24:17 GMT'] + etag: ['0x8D619B6E0E932B1'] + last-modified: ['Thu, 13 Sep 2018 20:24:16 GMT'] + request-id: [6a321b07-a30e-4e14-a475-ed010e819c5a] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -204,10 +204,10 @@ interactions: Connection: [keep-alive] Content-Length: ['128'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:16 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:17 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: @@ -215,11 +215,11 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:16 GMT'] - etag: ['0x8D609F4876B4136'] - last-modified: ['Fri, 24 Aug 2018 19:05:16 GMT'] + date: ['Thu, 13 Sep 2018 20:24:18 GMT'] + etag: ['0x8D619B6E1B80467'] + last-modified: ['Thu, 13 Sep 2018 20:24:18 GMT'] location: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6'] - request-id: [87822724-0237-4e9d-90bb-0747485a3b96] + request-id: [7205b4d0-f9d7-463b-9a7d-9dca01d3c6b4] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -231,14 +231,14 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:17 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:18 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task4_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6\",\"eTag\":\"0x8D609F4876B4136\",\"creationTime\":\"2018-08-24T19:05:16.8127286Z\",\"lastModified\":\"2018-08-24T19:05:16.8127286Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:16.8127286Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task4_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6\",\"eTag\":\"0x8D619B6E1B80467\",\"creationTime\":\"2018-09-13T20:24:18.1179495Z\",\"lastModified\":\"2018-09-13T20:24:18.1179495Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:18.1179495Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"authenticationTokenSettings\":{\r\n \ \"access\":[\r\n \"job\"\r\n ]\r\n },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n @@ -246,29 +246,29 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:16 GMT'] - etag: ['0x8D609F4876B4136'] - last-modified: ['Fri, 24 Aug 2018 19:05:16 GMT'] - request-id: [828b9ee4-85d6-429a-b062-0c0453136891] + date: ['Thu, 13 Sep 2018 20:24:17 GMT'] + etag: ['0x8D619B6E1B80467'] + last-modified: ['Thu, 13 Sep 2018 20:24:18 GMT'] + request-id: [0528c98a-ffb5-425e-b506-1073eeb9ebfd] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] x-content-type-options: [nosniff] status: {code: 200, message: OK} - request: - body: '{"containerSettings": {"imageName": "windows_container:latest", "registry": - {"password": "password", "username": "username"}}, "id": "batch_task5_98da0af6", - "commandLine": "cmd /c \"echo hello world\""}' + body: '{"id": "batch_task5_98da0af6", "commandLine": "cmd /c \"echo hello world\"", + "containerSettings": {"imageName": "windows_container:latest", "registry": {"username": + "username", "password": "password"}}}' headers: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['202'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:17 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:18 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: @@ -276,11 +276,11 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:18 GMT'] - etag: ['0x8D609F488533EEE'] - last-modified: ['Fri, 24 Aug 2018 19:05:18 GMT'] + date: ['Thu, 13 Sep 2018 20:24:19 GMT'] + etag: ['0x8D619B6E294BE8E'] + last-modified: ['Thu, 13 Sep 2018 20:24:19 GMT'] location: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6'] - request-id: [649731c8-44e5-40c9-bbcf-263720d091c3] + request-id: [9536888b-a663-420d-a5c9-97e83c98edbe] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -292,14 +292,14 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:18 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:19 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task5_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6\",\"eTag\":\"0x8D609F488533EEE\",\"creationTime\":\"2018-08-24T19:05:18.3331054Z\",\"lastModified\":\"2018-08-24T19:05:18.3331054Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:18.3331054Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task5_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6\",\"eTag\":\"0x8D619B6E294BE8E\",\"creationTime\":\"2018-09-13T20:24:19.564507Z\",\"lastModified\":\"2018-09-13T20:24:19.564507Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:19.564507Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"containerSettings\":{\r\n \"imageName\":\"windows_container:latest\",\"registry\":{\r\n \ \"username\":\"username\"\r\n }\r\n },\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"constraints\":{\r\n @@ -308,28 +308,28 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:19 GMT'] - etag: ['0x8D609F488533EEE'] - last-modified: ['Fri, 24 Aug 2018 19:05:18 GMT'] - request-id: [4a316047-0898-43ef-839c-969fd10470fa] + date: ['Thu, 13 Sep 2018 20:24:19 GMT'] + etag: ['0x8D619B6E294BE8E'] + last-modified: ['Thu, 13 Sep 2018 20:24:19 GMT'] + request-id: [fb107f3f-c564-4eac-9dbc-6403834e8c31] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] x-content-type-options: [nosniff] status: {code: 200, message: OK} - request: - body: '{"userIdentity": {"username": "task-user"}, "id": "batch_task6_98da0af6", - "commandLine": "cmd /c \"echo hello world\""}' + body: '{"id": "batch_task6_98da0af6", "commandLine": "cmd /c \"echo hello world\"", + "userIdentity": {"username": "task-user"}}' headers: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['119'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:19 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:20 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: @@ -337,11 +337,11 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:19 GMT'] - etag: ['0x8D609F4895089E4'] - last-modified: ['Fri, 24 Aug 2018 19:05:19 GMT'] + date: ['Thu, 13 Sep 2018 20:24:20 GMT'] + etag: ['0x8D619B6E37706DD'] + last-modified: ['Thu, 13 Sep 2018 20:24:21 GMT'] location: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6'] - request-id: [2fd6d331-25d9-44e3-bbbd-1bee85271ae0] + request-id: [b86fb5e6-efbc-473a-9fb3-2f08d89fad17] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -353,33 +353,33 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:20 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:21 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D609F4895089E4\",\"creationTime\":\"2018-08-24T19:05:19.9930852Z\",\"lastModified\":\"2018-08-24T19:05:19.9930852Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:19.9930852Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D619B6E37706DD\",\"creationTime\":\"2018-09-13T20:24:21.0474717Z\",\"lastModified\":\"2018-09-13T20:24:21.0474717Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:21.0474717Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"username\":\"task-user\"\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n }\r\n}"} headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:20 GMT'] - etag: ['0x8D609F4895089E4'] - last-modified: ['Fri, 24 Aug 2018 19:05:19 GMT'] - request-id: [92a86774-6598-4c21-9c5a-b165068f30e3] + date: ['Thu, 13 Sep 2018 20:24:21 GMT'] + etag: ['0x8D619B6E37706DD'] + last-modified: ['Thu, 13 Sep 2018 20:24:21 GMT'] + request-id: [0d037480-1739-4bf9-89cc-2459af87edcf] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] x-content-type-options: [nosniff] status: {code: 200, message: OK} - request: - body: '{"value": [{"id": "batch_task7_98da0af6", "commandLine": "cmd /c \"echo + body: '{"value": [{"id": "batch_task9_98da0af6", "commandLine": "cmd /c \"echo hello world\""}, {"id": "batch_task8_98da0af6", "commandLine": "cmd /c \"echo - hello world\""}, {"id": "batch_task9_98da0af6", "commandLine": "cmd /c \"echo + hello world\""}, {"id": "batch_task7_98da0af6", "commandLine": "cmd /c \"echo hello world\""}]}' headers: Accept: [application/json] @@ -387,23 +387,23 @@ interactions: Connection: [keep-alive] Content-Length: ['245'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:20 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:21 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 response: body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n - \ {\r\n \"status\":\"Success\",\"taskId\":\"batch_task7_98da0af6\",\"eTag\":\"0x8D609F48A3DFD27\",\"lastModified\":\"2018-08-24T19:05:21.5492391Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task7_98da0af6\"\r\n - \ },{\r\n \"status\":\"Success\",\"taskId\":\"batch_task8_98da0af6\",\"eTag\":\"0x8D609F48A3FFA0D\",\"lastModified\":\"2018-08-24T19:05:21.5622669Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task8_98da0af6\"\r\n - \ },{\r\n \"status\":\"Success\",\"taskId\":\"batch_task9_98da0af6\",\"eTag\":\"0x8D609F48A40473F\",\"lastModified\":\"2018-08-24T19:05:21.5642431Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task9_98da0af6\"\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"batch_task9_98da0af6\",\"eTag\":\"0x8D619B6E45832CE\",\"lastModified\":\"2018-09-13T20:24:22.5231566Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task9_98da0af6\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"batch_task8_98da0af6\",\"eTag\":\"0x8D619B6E459B3D7\",\"lastModified\":\"2018-09-13T20:24:22.5330135Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task8_98da0af6\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"batch_task7_98da0af6\",\"eTag\":\"0x8D619B6E45A7C26\",\"lastModified\":\"2018-09-13T20:24:22.5381414Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task7_98da0af6\"\r\n \ }\r\n ]\r\n}"} headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:20 GMT'] - request-id: [7c88fba9-94d8-4e04-a2f4-fe7c4edb5121] + date: ['Thu, 13 Sep 2018 20:24:22 GMT'] + request-id: [1898479f-6559-4c79-89ab-92ac6616a1ed] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -415,15 +415,15 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:21 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:22 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks?api-version=2018-08-01.7.0 response: body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks\",\"value\":[\r\n - \ {\r\n \"id\":\"batch_task1_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6\",\"eTag\":\"0x8D609F4845DC881\",\"creationTime\":\"2018-08-24T19:05:11.6912769Z\",\"lastModified\":\"2018-08-24T19:05:11.6912769Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:11.6912769Z\",\"commandLine\":\"cmd + \ {\r\n \"id\":\"batch_task1_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task1_98da0af6\",\"eTag\":\"0x8D619B6DF299ACC\",\"creationTime\":\"2018-09-13T20:24:13.8291916Z\",\"lastModified\":\"2018-09-13T20:24:13.8291916Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:13.8291916Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"exitConditions\":{\r\n \ \"exitCodes\":[\r\n {\r\n \"code\":1,\"exitOptions\":{\r\n @@ -433,7 +433,7 @@ interactions: \ ],\"default\":{\r\n \"jobAction\":\"none\"\r\n }\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task2_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6\",\"eTag\":\"0x8D609F4857AAFDF\",\"creationTime\":\"2018-08-24T19:05:13.5584223Z\",\"lastModified\":\"2018-08-24T19:05:13.5584223Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:13.5584223Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task2_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task2_98da0af6\",\"eTag\":\"0x8D619B6E00C2310\",\"creationTime\":\"2018-09-13T20:24:15.3137936Z\",\"lastModified\":\"2018-09-13T20:24:15.3137936Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:15.3137936Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"outputFiles\":[\r\n {\r\n \"filePattern\":\"../stdout.txt\",\"destination\":{\r\n \ \"container\":{\r\n \"containerUrl\":\"https://test.blob.core.windows.net:443/test-container\",\"path\":\"taskLogs/output.txt\"\r\n \ }\r\n },\"uploadOptions\":{\r\n \"uploadCondition\":\"TaskCompletion\"\r\n @@ -444,38 +444,38 @@ interactions: \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"constraints\":{\r\n \ \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task3_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6\",\"eTag\":\"0x8D609F4867C422C\",\"creationTime\":\"2018-08-24T19:05:15.2464428Z\",\"lastModified\":\"2018-08-24T19:05:15.2464428Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:15.2464428Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task3_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task3_98da0af6\",\"eTag\":\"0x8D619B6E0E932B1\",\"creationTime\":\"2018-09-13T20:24:16.7625393Z\",\"lastModified\":\"2018-09-13T20:24:16.7625393Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:16.7625393Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"scope\":\"task\",\"elevationLevel\":\"admin\"\r\n }\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task4_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6\",\"eTag\":\"0x8D609F4876B4136\",\"creationTime\":\"2018-08-24T19:05:16.8127286Z\",\"lastModified\":\"2018-08-24T19:05:16.8127286Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:16.8127286Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task4_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task4_98da0af6\",\"eTag\":\"0x8D619B6E1B80467\",\"creationTime\":\"2018-09-13T20:24:18.1179495Z\",\"lastModified\":\"2018-09-13T20:24:18.1179495Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:18.1179495Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"authenticationTokenSettings\":{\r\n \ \"access\":[\r\n \"job\"\r\n ]\r\n },\"constraints\":{\r\n \ \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task5_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6\",\"eTag\":\"0x8D609F488533EEE\",\"creationTime\":\"2018-08-24T19:05:18.3331054Z\",\"lastModified\":\"2018-08-24T19:05:18.3331054Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:18.3331054Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task5_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task5_98da0af6\",\"eTag\":\"0x8D619B6E294BE8E\",\"creationTime\":\"2018-09-13T20:24:19.564507Z\",\"lastModified\":\"2018-09-13T20:24:19.564507Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:19.564507Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"containerSettings\":{\r\n \"imageName\":\"windows_container:latest\",\"registry\":{\r\n \ \"username\":\"username\"\r\n }\r\n },\"userIdentity\":{\r\n \ \"autoUser\":{\r\n \"elevationLevel\":\"nonadmin\"\r\n }\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D609F4895089E4\",\"creationTime\":\"2018-08-24T19:05:19.9930852Z\",\"lastModified\":\"2018-08-24T19:05:19.9930852Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:19.9930852Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D619B6E37706DD\",\"creationTime\":\"2018-09-13T20:24:21.0474717Z\",\"lastModified\":\"2018-09-13T20:24:21.0474717Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:21.0474717Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"username\":\"task-user\"\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task7_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task7_98da0af6\",\"eTag\":\"0x8D609F48A3DFD27\",\"creationTime\":\"2018-08-24T19:05:21.5492391Z\",\"lastModified\":\"2018-08-24T19:05:21.5492391Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:21.5492391Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task7_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task7_98da0af6\",\"eTag\":\"0x8D619B6E45A7C26\",\"creationTime\":\"2018-09-13T20:24:22.5381414Z\",\"lastModified\":\"2018-09-13T20:24:22.5381414Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:22.5381414Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"constraints\":{\r\n \ \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task8_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task8_98da0af6\",\"eTag\":\"0x8D609F48A3FFA0D\",\"creationTime\":\"2018-08-24T19:05:21.5622669Z\",\"lastModified\":\"2018-08-24T19:05:21.5622669Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:21.5622669Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task8_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task8_98da0af6\",\"eTag\":\"0x8D619B6E459B3D7\",\"creationTime\":\"2018-09-13T20:24:22.5330135Z\",\"lastModified\":\"2018-09-13T20:24:22.5330135Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:22.5330135Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"constraints\":{\r\n \ \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n - \ }\r\n },{\r\n \"id\":\"batch_task9_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task9_98da0af6\",\"eTag\":\"0x8D609F48A40473F\",\"creationTime\":\"2018-08-24T19:05:21.5642431Z\",\"lastModified\":\"2018-08-24T19:05:21.5642431Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:21.5642431Z\",\"commandLine\":\"cmd + \ }\r\n },{\r\n \"id\":\"batch_task9_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task9_98da0af6\",\"eTag\":\"0x8D619B6E45832CE\",\"creationTime\":\"2018-09-13T20:24:22.5231566Z\",\"lastModified\":\"2018-09-13T20:24:22.5231566Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:22.5231566Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"autoUser\":{\r\n \ \"elevationLevel\":\"nonadmin\"\r\n }\r\n },\"constraints\":{\r\n \ \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n @@ -484,8 +484,8 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:22 GMT'] - request-id: [4022aa80-b7f6-4dde-811f-c906754ae108] + date: ['Thu, 13 Sep 2018 20:24:23 GMT'] + request-id: [13700db5-3340-47ef-b198-2408e1d63037] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -497,19 +497,19 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:22 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:23 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/taskcounts?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskcounts/@Element\",\"active\":6,\"running\":0,\"completed\":0,\"succeeded\":0,\"failed\":0\r\n}"} + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskcounts/@Element\",\"active\":5,\"running\":0,\"completed\":0,\"succeeded\":0,\"failed\":0\r\n}"} headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:23 GMT'] - request-id: [d6b1a454-e039-4920-b951-f28802329b5b] + date: ['Thu, 13 Sep 2018 20:24:23 GMT'] + request-id: [33ff3ec5-9c15-48df-b41d-f667c39e6ad7] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -522,10 +522,10 @@ interactions: Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['0'] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:23 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:24 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6/terminate?api-version=2018-08-01.7.0 response: @@ -534,10 +534,10 @@ interactions: content-length: ['0'] dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6/terminate'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:24 GMT'] - etag: ['0x8D609F48BCA6916'] - last-modified: ['Fri, 24 Aug 2018 19:05:24 GMT'] - request-id: [9bf8bdaa-543d-437e-a726-682c679aa258] + date: ['Thu, 13 Sep 2018 20:24:24 GMT'] + etag: ['0x8D619B6E59FE6ED'] + last-modified: ['Thu, 13 Sep 2018 20:24:24 GMT'] + request-id: [ed3b8a68-6c36-496b-b911-b4c657378e27] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] x-content-type-options: [nosniff] @@ -548,27 +548,27 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:24 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:24 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D609F48BCA6916\",\"creationTime\":\"2018-08-24T19:05:19.9930852Z\",\"lastModified\":\"2018-08-24T19:05:24.1472278Z\",\"state\":\"completed\",\"stateTransitionTime\":\"2018-08-24T19:05:24.1472278Z\",\"previousState\":\"active\",\"previousStateTransitionTime\":\"2018-08-24T19:05:19.9930852Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D619B6E59FE6ED\",\"creationTime\":\"2018-09-13T20:24:21.0474717Z\",\"lastModified\":\"2018-09-13T20:24:24.6707949Z\",\"state\":\"completed\",\"stateTransitionTime\":\"2018-09-13T20:24:24.6707949Z\",\"previousState\":\"active\",\"previousStateTransitionTime\":\"2018-09-13T20:24:21.0474717Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"username\":\"task-user\"\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n - \ },\"executionInfo\":{\r\n \"endTime\":\"2018-08-24T19:05:24.1472278Z\",\"failureInfo\":{\r\n + \ },\"executionInfo\":{\r\n \"endTime\":\"2018-09-13T20:24:24.6707949Z\",\"failureInfo\":{\r\n \ \"category\":\"UserError\",\"code\":\"TaskEnded\",\"message\":\"Task - Was Ended by User Request\"\r\n },\"result\":\"Failure\",\"retryCount\":0,\"requeueCount\":0\r\n + Was Ended by User Request\"\r\n },\"result\":\"failure\",\"retryCount\":0,\"requeueCount\":0\r\n \ },\"nodeInfo\":{\r\n \r\n }\r\n}"} headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:24 GMT'] - etag: ['0x8D609F48BCA6916'] - last-modified: ['Fri, 24 Aug 2018 19:05:24 GMT'] - request-id: [2ee2a963-6c38-4772-a880-df1ade25acd7] + date: ['Thu, 13 Sep 2018 20:24:25 GMT'] + etag: ['0x8D619B6E59FE6ED'] + last-modified: ['Thu, 13 Sep 2018 20:24:24 GMT'] + request-id: [644b2957-ffbb-47f4-b9ce-37a1271ada54] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -581,10 +581,10 @@ interactions: Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['0'] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:25 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:25 GMT'] method: POST uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6/reactivate?api-version=2018-08-01.7.0 response: @@ -592,10 +592,10 @@ interactions: headers: content-length: ['0'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:25 GMT'] - etag: ['0x8D609F48CD2BCDA'] - last-modified: ['Fri, 24 Aug 2018 19:05:25 GMT'] - request-id: [856bc631-c1af-46bb-bd52-dda713f7c096] + date: ['Thu, 13 Sep 2018 20:24:26 GMT'] + etag: ['0x8D619B6E685F290'] + last-modified: ['Thu, 13 Sep 2018 20:24:26 GMT'] + request-id: [1682ad48-8b6b-4014-8c1c-d25ea49842c2] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] x-content-type-options: [nosniff] @@ -606,24 +606,24 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:26 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:26 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6?api-version=2018-08-01.7.0 response: - body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D609F48CD2BCDA\",\"creationTime\":\"2018-08-24T19:05:19.9930852Z\",\"lastModified\":\"2018-08-24T19:05:25.8795226Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-08-24T19:05:25.8795226Z\",\"previousState\":\"completed\",\"previousStateTransitionTime\":\"2018-08-24T19:05:24.1472278Z\",\"commandLine\":\"cmd + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#tasks/@Element\",\"id\":\"batch_task6_98da0af6\",\"url\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6\",\"eTag\":\"0x8D619B6E685F290\",\"creationTime\":\"2018-09-13T20:24:21.0474717Z\",\"lastModified\":\"2018-09-13T20:24:26.1784208Z\",\"state\":\"active\",\"stateTransitionTime\":\"2018-09-13T20:24:26.1784208Z\",\"previousState\":\"completed\",\"previousStateTransitionTime\":\"2018-09-13T20:24:24.6707949Z\",\"commandLine\":\"cmd /c \\\"echo hello world\\\"\",\"userIdentity\":{\r\n \"username\":\"task-user\"\r\n \ },\"constraints\":{\r\n \"maxWallClockTime\":\"P10675199DT2H48M5.4775807S\",\"retentionTime\":\"P10675199DT2H48M5.4775807S\",\"maxTaskRetryCount\":0\r\n \ },\"executionInfo\":{\r\n \"retryCount\":0,\"requeueCount\":0\r\n }\r\n}"} headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:26 GMT'] - etag: ['0x8D609F48CD2BCDA'] - last-modified: ['Fri, 24 Aug 2018 19:05:25 GMT'] - request-id: [068cbb41-f282-4b28-b6f4-9b23754811df] + date: ['Thu, 13 Sep 2018 20:24:26 GMT'] + etag: ['0x8D619B6E685F290'] + last-modified: ['Thu, 13 Sep 2018 20:24:26 GMT'] + request-id: [432131a9-24eb-4146-820f-774b4eb318a6] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -637,10 +637,10 @@ interactions: Connection: [keep-alive] Content-Length: ['41'] Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:27 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:26 GMT'] method: PUT uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6?api-version=2018-08-01.7.0 response: @@ -648,10 +648,10 @@ interactions: headers: dataserviceid: ['https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6'] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:27 GMT'] - etag: ['0x8D609F48DF0FE35'] - last-modified: ['Fri, 24 Aug 2018 19:05:27 GMT'] - request-id: [8ed8f53e-641b-4527-91c1-b6ec98e041b5] + date: ['Thu, 13 Sep 2018 20:24:27 GMT'] + etag: ['0x8D619B6E75CCEF0'] + last-modified: ['Thu, 13 Sep 2018 20:24:27 GMT'] + request-id: [6ff24bbc-96b5-4704-9e41-48a558aefd30] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -663,10 +663,10 @@ interactions: Accept: [application/json] Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:27 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:27 GMT'] method: GET uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6/subtasksinfo?api-version=2018-08-01.7.0 response: @@ -675,8 +675,8 @@ interactions: headers: content-type: [application/json;odata=minimalmetadata] dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:28 GMT'] - request-id: [bce94654-6b70-45f8-be8c-c4a3192d00af] + date: ['Thu, 13 Sep 2018 20:24:28 GMT'] + request-id: [de6c723b-866a-4b8b-9975-8849bf62c6dc] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] @@ -689,18 +689,95352 @@ interactions: Accept-Encoding: ['gzip, deflate'] Connection: [keep-alive] Content-Length: ['0'] - User-Agent: [python/3.5.4 (Windows-2008ServerR2-6.1.7601-SP1) requests/2.19.1 - msrest/0.5.4 msrest_azure/0.4.34 azure-batch/5.0.0 Azure-SDK-For-Python] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] accept-language: [en-US] - ocp-date: ['Fri, 24 Aug 2018 19:05:28 GMT'] + ocp-date: ['Thu, 13 Sep 2018 20:24:28 GMT'] method: DELETE uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/batch_task6_98da0af6?api-version=2018-08-01.7.0 response: body: {string: ''} headers: dataserviceversion: ['3.0'] - date: ['Fri, 24 Aug 2018 19:05:29 GMT'] - request-id: [1a5ef46b-6b9f-4f84-9ea4-890213c525d2] + date: ['Thu, 13 Sep 2018 20:24:28 GMT'] + request-id: [242e5bef-f6da-4454-ace7-09651ed3b132] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile100", + "filePath": "resourceFile100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile101", + "filePath": "resourceFile101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile102", + "filePath": "resourceFile102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile103", + "filePath": "resourceFile103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile104", + "filePath": "resourceFile104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile105", + "filePath": "resourceFile105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile106", + "filePath": "resourceFile106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile107", + "filePath": "resourceFile107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile108", + "filePath": "resourceFile108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile109", + "filePath": "resourceFile109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile110", + "filePath": "resourceFile110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile111", + "filePath": "resourceFile111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile112", + "filePath": "resourceFile112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile113", + "filePath": "resourceFile113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile114", + "filePath": "resourceFile114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile115", + "filePath": "resourceFile115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile116", + "filePath": "resourceFile116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile117", + "filePath": "resourceFile117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile118", + "filePath": "resourceFile118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile119", + "filePath": "resourceFile119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile120", + "filePath": "resourceFile120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile121", + "filePath": "resourceFile121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile122", + "filePath": "resourceFile122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile123", + "filePath": "resourceFile123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile124", + "filePath": "resourceFile124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile125", + "filePath": "resourceFile125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile126", + "filePath": "resourceFile126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile127", + "filePath": "resourceFile127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile128", + "filePath": "resourceFile128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile129", + "filePath": "resourceFile129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile130", + "filePath": "resourceFile130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile131", + "filePath": "resourceFile131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile132", + "filePath": "resourceFile132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile133", + "filePath": "resourceFile133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile134", + "filePath": "resourceFile134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile135", + "filePath": "resourceFile135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile136", + "filePath": "resourceFile136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile137", + "filePath": "resourceFile137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile138", + "filePath": "resourceFile138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile139", + "filePath": "resourceFile139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile140", + "filePath": "resourceFile140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile141", + "filePath": "resourceFile141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile142", + "filePath": "resourceFile142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile143", + "filePath": "resourceFile143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile144", + "filePath": "resourceFile144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile145", + "filePath": "resourceFile145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile146", + "filePath": "resourceFile146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile147", + "filePath": "resourceFile147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile148", + "filePath": "resourceFile148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile149", + "filePath": "resourceFile149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile150", + "filePath": "resourceFile150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile151", + "filePath": "resourceFile151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile152", + "filePath": "resourceFile152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile153", + "filePath": "resourceFile153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile154", + "filePath": "resourceFile154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile155", + "filePath": "resourceFile155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile156", + "filePath": "resourceFile156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile157", + "filePath": "resourceFile157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile158", + "filePath": "resourceFile158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile159", + "filePath": "resourceFile159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile160", + "filePath": "resourceFile160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile161", + "filePath": "resourceFile161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile162", + "filePath": "resourceFile162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile163", + "filePath": "resourceFile163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile164", + "filePath": "resourceFile164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile165", + "filePath": "resourceFile165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile166", + "filePath": "resourceFile166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile167", + "filePath": "resourceFile167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile168", + "filePath": "resourceFile168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile169", + "filePath": "resourceFile169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile170", + "filePath": "resourceFile170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile171", + "filePath": "resourceFile171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile172", + "filePath": "resourceFile172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile173", + "filePath": "resourceFile173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile174", + "filePath": "resourceFile174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile175", + "filePath": "resourceFile175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile176", + "filePath": "resourceFile176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile177", + "filePath": "resourceFile177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile178", + "filePath": "resourceFile178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile179", + "filePath": "resourceFile179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile180", + "filePath": "resourceFile180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile181", + "filePath": "resourceFile181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile182", + "filePath": "resourceFile182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile183", + "filePath": "resourceFile183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile184", + "filePath": "resourceFile184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile185", + "filePath": "resourceFile185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile186", + "filePath": "resourceFile186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile187", + "filePath": "resourceFile187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile188", + "filePath": "resourceFile188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile189", + "filePath": "resourceFile189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile190", + "filePath": "resourceFile190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile191", + "filePath": "resourceFile191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile192", + "filePath": "resourceFile192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile193", + "filePath": "resourceFile193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile194", + "filePath": "resourceFile194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile195", + "filePath": "resourceFile195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile196", + "filePath": "resourceFile196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile197", + "filePath": "resourceFile197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile198", + "filePath": "resourceFile198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile199", + "filePath": "resourceFile199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile200", + "filePath": "resourceFile200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile201", + "filePath": "resourceFile201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile202", + "filePath": "resourceFile202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile203", + "filePath": "resourceFile203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile204", + "filePath": "resourceFile204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile205", + "filePath": "resourceFile205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile206", + "filePath": "resourceFile206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile207", + "filePath": "resourceFile207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile208", + "filePath": "resourceFile208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile209", + "filePath": "resourceFile209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile210", + "filePath": "resourceFile210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile211", + "filePath": "resourceFile211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile212", + "filePath": "resourceFile212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile213", + "filePath": "resourceFile213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile214", + "filePath": "resourceFile214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile215", + "filePath": "resourceFile215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile216", + "filePath": "resourceFile216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile217", + "filePath": "resourceFile217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile218", + "filePath": "resourceFile218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile219", + "filePath": "resourceFile219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile220", + "filePath": "resourceFile220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile221", + "filePath": "resourceFile221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile222", + "filePath": "resourceFile222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile223", + "filePath": "resourceFile223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile224", + "filePath": "resourceFile224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile225", + "filePath": "resourceFile225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile226", + "filePath": "resourceFile226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile227", + "filePath": "resourceFile227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile228", + "filePath": "resourceFile228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile229", + "filePath": "resourceFile229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile230", + "filePath": "resourceFile230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile231", + "filePath": "resourceFile231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile232", + "filePath": "resourceFile232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile233", + "filePath": "resourceFile233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile234", + "filePath": "resourceFile234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile235", + "filePath": "resourceFile235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile236", + "filePath": "resourceFile236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile237", + "filePath": "resourceFile237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile238", + "filePath": "resourceFile238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile239", + "filePath": "resourceFile239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile240", + "filePath": "resourceFile240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile241", + "filePath": "resourceFile241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile242", + "filePath": "resourceFile242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile243", + "filePath": "resourceFile243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile244", + "filePath": "resourceFile244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile245", + "filePath": "resourceFile245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile246", + "filePath": "resourceFile246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile247", + "filePath": "resourceFile247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile248", + "filePath": "resourceFile248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile249", + "filePath": "resourceFile249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile250", + "filePath": "resourceFile250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile251", + "filePath": "resourceFile251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile252", + "filePath": "resourceFile252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile253", + "filePath": "resourceFile253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile254", + "filePath": "resourceFile254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile255", + "filePath": "resourceFile255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile256", + "filePath": "resourceFile256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile257", + "filePath": "resourceFile257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile258", + "filePath": "resourceFile258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile259", + "filePath": "resourceFile259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile260", + "filePath": "resourceFile260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile261", + "filePath": "resourceFile261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile262", + "filePath": "resourceFile262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile263", + "filePath": "resourceFile263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile264", + "filePath": "resourceFile264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile265", + "filePath": "resourceFile265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile266", + "filePath": "resourceFile266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile267", + "filePath": "resourceFile267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile268", + "filePath": "resourceFile268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile269", + "filePath": "resourceFile269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile270", + "filePath": "resourceFile270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile271", + "filePath": "resourceFile271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile272", + "filePath": "resourceFile272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile273", + "filePath": "resourceFile273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile274", + "filePath": "resourceFile274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile275", + "filePath": "resourceFile275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile276", + "filePath": "resourceFile276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile277", + "filePath": "resourceFile277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile278", + "filePath": "resourceFile278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile279", + "filePath": "resourceFile279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile280", + "filePath": "resourceFile280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile281", + "filePath": "resourceFile281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile282", + "filePath": "resourceFile282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile283", + "filePath": "resourceFile283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile284", + "filePath": "resourceFile284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile285", + "filePath": "resourceFile285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile286", + "filePath": "resourceFile286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile287", + "filePath": "resourceFile287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile288", + "filePath": "resourceFile288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile289", + "filePath": "resourceFile289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile290", + "filePath": "resourceFile290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile291", + "filePath": "resourceFile291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile292", + "filePath": "resourceFile292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile293", + "filePath": "resourceFile293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile294", + "filePath": "resourceFile294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile295", + "filePath": "resourceFile295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile296", + "filePath": "resourceFile296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile297", + "filePath": "resourceFile297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile298", + "filePath": "resourceFile298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile299", + "filePath": "resourceFile299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile300", + "filePath": "resourceFile300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile301", + "filePath": "resourceFile301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile302", + "filePath": "resourceFile302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile303", + "filePath": "resourceFile303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile304", + "filePath": "resourceFile304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile305", + "filePath": "resourceFile305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile306", + "filePath": "resourceFile306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile307", + "filePath": "resourceFile307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile308", + "filePath": "resourceFile308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile309", + "filePath": "resourceFile309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile310", + "filePath": "resourceFile310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile311", + "filePath": "resourceFile311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile312", + "filePath": "resourceFile312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile313", + "filePath": "resourceFile313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile314", + "filePath": "resourceFile314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile315", + "filePath": "resourceFile315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile316", + "filePath": "resourceFile316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile317", + "filePath": "resourceFile317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile318", + "filePath": "resourceFile318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile319", + "filePath": "resourceFile319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile320", + "filePath": "resourceFile320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile321", + "filePath": "resourceFile321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile322", + "filePath": "resourceFile322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile323", + "filePath": "resourceFile323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile324", + "filePath": "resourceFile324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile325", + "filePath": "resourceFile325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile326", + "filePath": "resourceFile326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile327", + "filePath": "resourceFile327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile328", + "filePath": "resourceFile328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile329", + "filePath": "resourceFile329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile330", + "filePath": "resourceFile330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile331", + "filePath": "resourceFile331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile332", + "filePath": "resourceFile332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile333", + "filePath": "resourceFile333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile334", + "filePath": "resourceFile334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile335", + "filePath": "resourceFile335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile336", + "filePath": "resourceFile336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile337", + "filePath": "resourceFile337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile338", + "filePath": "resourceFile338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile339", + "filePath": "resourceFile339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile340", + "filePath": "resourceFile340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile341", + "filePath": "resourceFile341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile342", + "filePath": "resourceFile342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile343", + "filePath": "resourceFile343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile344", + "filePath": "resourceFile344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile345", + "filePath": "resourceFile345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile346", + "filePath": "resourceFile346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile347", + "filePath": "resourceFile347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile348", + "filePath": "resourceFile348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile349", + "filePath": "resourceFile349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile350", + "filePath": "resourceFile350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile351", + "filePath": "resourceFile351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile352", + "filePath": "resourceFile352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile353", + "filePath": "resourceFile353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile354", + "filePath": "resourceFile354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile355", + "filePath": "resourceFile355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile356", + "filePath": "resourceFile356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile357", + "filePath": "resourceFile357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile358", + "filePath": "resourceFile358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile359", + "filePath": "resourceFile359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile360", + "filePath": "resourceFile360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile361", + "filePath": "resourceFile361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile362", + "filePath": "resourceFile362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile363", + "filePath": "resourceFile363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile364", + "filePath": "resourceFile364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile365", + "filePath": "resourceFile365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile366", + "filePath": "resourceFile366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile367", + "filePath": "resourceFile367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile368", + "filePath": "resourceFile368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile369", + "filePath": "resourceFile369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile370", + "filePath": "resourceFile370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile371", + "filePath": "resourceFile371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile372", + "filePath": "resourceFile372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile373", + "filePath": "resourceFile373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile374", + "filePath": "resourceFile374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile375", + "filePath": "resourceFile375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile376", + "filePath": "resourceFile376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile377", + "filePath": "resourceFile377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile378", + "filePath": "resourceFile378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile379", + "filePath": "resourceFile379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile380", + "filePath": "resourceFile380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile381", + "filePath": "resourceFile381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile382", + "filePath": "resourceFile382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile383", + "filePath": "resourceFile383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile384", + "filePath": "resourceFile384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile385", + "filePath": "resourceFile385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile386", + "filePath": "resourceFile386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile387", + "filePath": "resourceFile387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile388", + "filePath": "resourceFile388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile389", + "filePath": "resourceFile389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile390", + "filePath": "resourceFile390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile391", + "filePath": "resourceFile391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile392", + "filePath": "resourceFile392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile393", + "filePath": "resourceFile393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile394", + "filePath": "resourceFile394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile395", + "filePath": "resourceFile395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile396", + "filePath": "resourceFile396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile397", + "filePath": "resourceFile397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile398", + "filePath": "resourceFile398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile399", + "filePath": "resourceFile399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile400", + "filePath": "resourceFile400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile401", + "filePath": "resourceFile401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile402", + "filePath": "resourceFile402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile403", + "filePath": "resourceFile403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile404", + "filePath": "resourceFile404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile405", + "filePath": "resourceFile405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile406", + "filePath": "resourceFile406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile407", + "filePath": "resourceFile407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile408", + "filePath": "resourceFile408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile409", + "filePath": "resourceFile409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile410", + "filePath": "resourceFile410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile411", + "filePath": "resourceFile411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile412", + "filePath": "resourceFile412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile413", + "filePath": "resourceFile413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile414", + "filePath": "resourceFile414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile415", + "filePath": "resourceFile415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile416", + "filePath": "resourceFile416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile417", + "filePath": "resourceFile417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile418", + "filePath": "resourceFile418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile419", + "filePath": "resourceFile419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile420", + "filePath": "resourceFile420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile421", + "filePath": "resourceFile421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile422", + "filePath": "resourceFile422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile423", + "filePath": "resourceFile423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile424", + "filePath": "resourceFile424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile425", + "filePath": "resourceFile425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile426", + "filePath": "resourceFile426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile427", + "filePath": "resourceFile427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile428", + "filePath": "resourceFile428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile429", + "filePath": "resourceFile429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile430", + "filePath": "resourceFile430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile431", + "filePath": "resourceFile431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile432", + "filePath": "resourceFile432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile433", + "filePath": "resourceFile433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile434", + "filePath": "resourceFile434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile435", + "filePath": "resourceFile435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile436", + "filePath": "resourceFile436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile437", + "filePath": "resourceFile437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile438", + "filePath": "resourceFile438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile439", + "filePath": "resourceFile439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile440", + "filePath": "resourceFile440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile441", + "filePath": "resourceFile441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile442", + "filePath": "resourceFile442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile443", + "filePath": "resourceFile443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile444", + "filePath": "resourceFile444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile445", + "filePath": "resourceFile445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile446", + "filePath": "resourceFile446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile447", + "filePath": "resourceFile447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile448", + "filePath": "resourceFile448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile449", + "filePath": "resourceFile449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile450", + "filePath": "resourceFile450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile451", + "filePath": "resourceFile451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile452", + "filePath": "resourceFile452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile453", + "filePath": "resourceFile453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile454", + "filePath": "resourceFile454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile455", + "filePath": "resourceFile455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile456", + "filePath": "resourceFile456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile457", + "filePath": "resourceFile457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile458", + "filePath": "resourceFile458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile459", + "filePath": "resourceFile459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile460", + "filePath": "resourceFile460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile461", + "filePath": "resourceFile461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile462", + "filePath": "resourceFile462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile463", + "filePath": "resourceFile463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile464", + "filePath": "resourceFile464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile465", + "filePath": "resourceFile465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile466", + "filePath": "resourceFile466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile467", + "filePath": "resourceFile467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile468", + "filePath": "resourceFile468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile469", + "filePath": "resourceFile469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile470", + "filePath": "resourceFile470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile471", + "filePath": "resourceFile471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile472", + "filePath": "resourceFile472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile473", + "filePath": "resourceFile473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile474", + "filePath": "resourceFile474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile475", + "filePath": "resourceFile475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile476", + "filePath": "resourceFile476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile477", + "filePath": "resourceFile477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile478", + "filePath": "resourceFile478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile479", + "filePath": "resourceFile479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile480", + "filePath": "resourceFile480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile481", + "filePath": "resourceFile481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile482", + "filePath": "resourceFile482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile483", + "filePath": "resourceFile483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile484", + "filePath": "resourceFile484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile485", + "filePath": "resourceFile485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile486", + "filePath": "resourceFile486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile487", + "filePath": "resourceFile487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile488", + "filePath": "resourceFile488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile489", + "filePath": "resourceFile489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile490", + "filePath": "resourceFile490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile491", + "filePath": "resourceFile491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile492", + "filePath": "resourceFile492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile493", + "filePath": "resourceFile493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile494", + "filePath": "resourceFile494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile495", + "filePath": "resourceFile495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile496", + "filePath": "resourceFile496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile497", + "filePath": "resourceFile497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile498", + "filePath": "resourceFile498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile499", + "filePath": "resourceFile499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile500", + "filePath": "resourceFile500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile501", + "filePath": "resourceFile501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile502", + "filePath": "resourceFile502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile503", + "filePath": "resourceFile503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile504", + "filePath": "resourceFile504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile505", + "filePath": "resourceFile505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile506", + "filePath": "resourceFile506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile507", + "filePath": "resourceFile507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile508", + "filePath": "resourceFile508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile509", + "filePath": "resourceFile509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile510", + "filePath": "resourceFile510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile511", + "filePath": "resourceFile511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile512", + "filePath": "resourceFile512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile513", + "filePath": "resourceFile513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile514", + "filePath": "resourceFile514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile515", + "filePath": "resourceFile515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile516", + "filePath": "resourceFile516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile517", + "filePath": "resourceFile517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile518", + "filePath": "resourceFile518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile519", + "filePath": "resourceFile519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile520", + "filePath": "resourceFile520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile521", + "filePath": "resourceFile521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile522", + "filePath": "resourceFile522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile523", + "filePath": "resourceFile523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile524", + "filePath": "resourceFile524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile525", + "filePath": "resourceFile525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile526", + "filePath": "resourceFile526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile527", + "filePath": "resourceFile527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile528", + "filePath": "resourceFile528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile529", + "filePath": "resourceFile529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile530", + "filePath": "resourceFile530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile531", + "filePath": "resourceFile531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile532", + "filePath": "resourceFile532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile533", + "filePath": "resourceFile533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile534", + "filePath": "resourceFile534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile535", + "filePath": "resourceFile535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile536", + "filePath": "resourceFile536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile537", + "filePath": "resourceFile537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile538", + "filePath": "resourceFile538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile539", + "filePath": "resourceFile539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile540", + "filePath": "resourceFile540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile541", + "filePath": "resourceFile541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile542", + "filePath": "resourceFile542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile543", + "filePath": "resourceFile543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile544", + "filePath": "resourceFile544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile545", + "filePath": "resourceFile545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile546", + "filePath": "resourceFile546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile547", + "filePath": "resourceFile547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile548", + "filePath": "resourceFile548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile549", + "filePath": "resourceFile549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile550", + "filePath": "resourceFile550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile551", + "filePath": "resourceFile551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile552", + "filePath": "resourceFile552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile553", + "filePath": "resourceFile553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile554", + "filePath": "resourceFile554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile555", + "filePath": "resourceFile555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile556", + "filePath": "resourceFile556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile557", + "filePath": "resourceFile557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile558", + "filePath": "resourceFile558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile559", + "filePath": "resourceFile559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile560", + "filePath": "resourceFile560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile561", + "filePath": "resourceFile561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile562", + "filePath": "resourceFile562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile563", + "filePath": "resourceFile563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile564", + "filePath": "resourceFile564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile565", + "filePath": "resourceFile565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile566", + "filePath": "resourceFile566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile567", + "filePath": "resourceFile567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile568", + "filePath": "resourceFile568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile569", + "filePath": "resourceFile569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile570", + "filePath": "resourceFile570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile571", + "filePath": "resourceFile571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile572", + "filePath": "resourceFile572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile573", + "filePath": "resourceFile573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile574", + "filePath": "resourceFile574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile575", + "filePath": "resourceFile575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile576", + "filePath": "resourceFile576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile577", + "filePath": "resourceFile577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile578", + "filePath": "resourceFile578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile579", + "filePath": "resourceFile579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile580", + "filePath": "resourceFile580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile581", + "filePath": "resourceFile581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile582", + "filePath": "resourceFile582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile583", + "filePath": "resourceFile583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile584", + "filePath": "resourceFile584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile585", + "filePath": "resourceFile585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile586", + "filePath": "resourceFile586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile587", + "filePath": "resourceFile587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile588", + "filePath": "resourceFile588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile589", + "filePath": "resourceFile589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile590", + "filePath": "resourceFile590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile591", + "filePath": "resourceFile591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile592", + "filePath": "resourceFile592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile593", + "filePath": "resourceFile593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile594", + "filePath": "resourceFile594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile595", + "filePath": "resourceFile595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile596", + "filePath": "resourceFile596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile597", + "filePath": "resourceFile597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile598", + "filePath": "resourceFile598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile599", + "filePath": "resourceFile599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile600", + "filePath": "resourceFile600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile601", + "filePath": "resourceFile601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile602", + "filePath": "resourceFile602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile603", + "filePath": "resourceFile603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile604", + "filePath": "resourceFile604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile605", + "filePath": "resourceFile605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile606", + "filePath": "resourceFile606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile607", + "filePath": "resourceFile607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile608", + "filePath": "resourceFile608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile609", + "filePath": "resourceFile609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile610", + "filePath": "resourceFile610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile611", + "filePath": "resourceFile611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile612", + "filePath": "resourceFile612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile613", + "filePath": "resourceFile613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile614", + "filePath": "resourceFile614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile615", + "filePath": "resourceFile615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile616", + "filePath": "resourceFile616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile617", + "filePath": "resourceFile617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile618", + "filePath": "resourceFile618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile619", + "filePath": "resourceFile619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile620", + "filePath": "resourceFile620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile621", + "filePath": "resourceFile621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile622", + "filePath": "resourceFile622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile623", + "filePath": "resourceFile623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile624", + "filePath": "resourceFile624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile625", + "filePath": "resourceFile625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile626", + "filePath": "resourceFile626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile627", + "filePath": "resourceFile627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile628", + "filePath": "resourceFile628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile629", + "filePath": "resourceFile629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile630", + "filePath": "resourceFile630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile631", + "filePath": "resourceFile631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile632", + "filePath": "resourceFile632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile633", + "filePath": "resourceFile633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile634", + "filePath": "resourceFile634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile635", + "filePath": "resourceFile635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile636", + "filePath": "resourceFile636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile637", + "filePath": "resourceFile637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile638", + "filePath": "resourceFile638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile639", + "filePath": "resourceFile639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile640", + "filePath": "resourceFile640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile641", + "filePath": "resourceFile641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile642", + "filePath": "resourceFile642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile643", + "filePath": "resourceFile643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile644", + "filePath": "resourceFile644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile645", + "filePath": "resourceFile645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile646", + "filePath": "resourceFile646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile647", + "filePath": "resourceFile647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile648", + "filePath": "resourceFile648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile649", + "filePath": "resourceFile649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile650", + "filePath": "resourceFile650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile651", + "filePath": "resourceFile651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile652", + "filePath": "resourceFile652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile653", + "filePath": "resourceFile653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile654", + "filePath": "resourceFile654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile655", + "filePath": "resourceFile655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile656", + "filePath": "resourceFile656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile657", + "filePath": "resourceFile657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile658", + "filePath": "resourceFile658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile659", + "filePath": "resourceFile659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile660", + "filePath": "resourceFile660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile661", + "filePath": "resourceFile661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile662", + "filePath": "resourceFile662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile663", + "filePath": "resourceFile663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile664", + "filePath": "resourceFile664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile665", + "filePath": "resourceFile665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile666", + "filePath": "resourceFile666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile667", + "filePath": "resourceFile667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile668", + "filePath": "resourceFile668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile669", + "filePath": "resourceFile669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile670", + "filePath": "resourceFile670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile671", + "filePath": "resourceFile671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile672", + "filePath": "resourceFile672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile673", + "filePath": "resourceFile673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile674", + "filePath": "resourceFile674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile675", + "filePath": "resourceFile675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile676", + "filePath": "resourceFile676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile677", + "filePath": "resourceFile677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile678", + "filePath": "resourceFile678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile679", + "filePath": "resourceFile679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile680", + "filePath": "resourceFile680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile681", + "filePath": "resourceFile681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile682", + "filePath": "resourceFile682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile683", + "filePath": "resourceFile683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile684", + "filePath": "resourceFile684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile685", + "filePath": "resourceFile685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile686", + "filePath": "resourceFile686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile687", + "filePath": "resourceFile687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile688", + "filePath": "resourceFile688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile689", + "filePath": "resourceFile689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile690", + "filePath": "resourceFile690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile691", + "filePath": "resourceFile691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile692", + "filePath": "resourceFile692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile693", + "filePath": "resourceFile693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile694", + "filePath": "resourceFile694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile695", + "filePath": "resourceFile695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile696", + "filePath": "resourceFile696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile697", + "filePath": "resourceFile697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile698", + "filePath": "resourceFile698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile699", + "filePath": "resourceFile699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile700", + "filePath": "resourceFile700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile701", + "filePath": "resourceFile701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile702", + "filePath": "resourceFile702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile703", + "filePath": "resourceFile703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile704", + "filePath": "resourceFile704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile705", + "filePath": "resourceFile705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile706", + "filePath": "resourceFile706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile707", + "filePath": "resourceFile707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile708", + "filePath": "resourceFile708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile709", + "filePath": "resourceFile709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile710", + "filePath": "resourceFile710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile711", + "filePath": "resourceFile711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile712", + "filePath": "resourceFile712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile713", + "filePath": "resourceFile713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile714", + "filePath": "resourceFile714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile715", + "filePath": "resourceFile715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile716", + "filePath": "resourceFile716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile717", + "filePath": "resourceFile717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile718", + "filePath": "resourceFile718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile719", + "filePath": "resourceFile719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile720", + "filePath": "resourceFile720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile721", + "filePath": "resourceFile721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile722", + "filePath": "resourceFile722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile723", + "filePath": "resourceFile723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile724", + "filePath": "resourceFile724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile725", + "filePath": "resourceFile725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile726", + "filePath": "resourceFile726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile727", + "filePath": "resourceFile727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile728", + "filePath": "resourceFile728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile729", + "filePath": "resourceFile729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile730", + "filePath": "resourceFile730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile731", + "filePath": "resourceFile731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile732", + "filePath": "resourceFile732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile733", + "filePath": "resourceFile733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile734", + "filePath": "resourceFile734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile735", + "filePath": "resourceFile735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile736", + "filePath": "resourceFile736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile737", + "filePath": "resourceFile737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile738", + "filePath": "resourceFile738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile739", + "filePath": "resourceFile739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile740", + "filePath": "resourceFile740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile741", + "filePath": "resourceFile741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile742", + "filePath": "resourceFile742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile743", + "filePath": "resourceFile743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile744", + "filePath": "resourceFile744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile745", + "filePath": "resourceFile745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile746", + "filePath": "resourceFile746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile747", + "filePath": "resourceFile747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile748", + "filePath": "resourceFile748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile749", + "filePath": "resourceFile749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile750", + "filePath": "resourceFile750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile751", + "filePath": "resourceFile751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile752", + "filePath": "resourceFile752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile753", + "filePath": "resourceFile753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile754", + "filePath": "resourceFile754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile755", + "filePath": "resourceFile755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile756", + "filePath": "resourceFile756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile757", + "filePath": "resourceFile757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile758", + "filePath": "resourceFile758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile759", + "filePath": "resourceFile759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile760", + "filePath": "resourceFile760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile761", + "filePath": "resourceFile761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile762", + "filePath": "resourceFile762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile763", + "filePath": "resourceFile763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile764", + "filePath": "resourceFile764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile765", + "filePath": "resourceFile765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile766", + "filePath": "resourceFile766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile767", + "filePath": "resourceFile767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile768", + "filePath": "resourceFile768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile769", + "filePath": "resourceFile769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile770", + "filePath": "resourceFile770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile771", + "filePath": "resourceFile771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile772", + "filePath": "resourceFile772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile773", + "filePath": "resourceFile773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile774", + "filePath": "resourceFile774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile775", + "filePath": "resourceFile775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile776", + "filePath": "resourceFile776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile777", + "filePath": "resourceFile777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile778", + "filePath": "resourceFile778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile779", + "filePath": "resourceFile779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile780", + "filePath": "resourceFile780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile781", + "filePath": "resourceFile781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile782", + "filePath": "resourceFile782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile783", + "filePath": "resourceFile783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile784", + "filePath": "resourceFile784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile785", + "filePath": "resourceFile785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile786", + "filePath": "resourceFile786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile787", + "filePath": "resourceFile787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile788", + "filePath": "resourceFile788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile789", + "filePath": "resourceFile789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile790", + "filePath": "resourceFile790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile791", + "filePath": "resourceFile791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile792", + "filePath": "resourceFile792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile793", + "filePath": "resourceFile793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile794", + "filePath": "resourceFile794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile795", + "filePath": "resourceFile795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile796", + "filePath": "resourceFile796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile797", + "filePath": "resourceFile797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile798", + "filePath": "resourceFile798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile799", + "filePath": "resourceFile799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile800", + "filePath": "resourceFile800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile801", + "filePath": "resourceFile801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile802", + "filePath": "resourceFile802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile803", + "filePath": "resourceFile803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile804", + "filePath": "resourceFile804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile805", + "filePath": "resourceFile805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile806", + "filePath": "resourceFile806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile807", + "filePath": "resourceFile807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile808", + "filePath": "resourceFile808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile809", + "filePath": "resourceFile809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile810", + "filePath": "resourceFile810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile811", + "filePath": "resourceFile811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile812", + "filePath": "resourceFile812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile813", + "filePath": "resourceFile813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile814", + "filePath": "resourceFile814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile815", + "filePath": "resourceFile815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile816", + "filePath": "resourceFile816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile817", + "filePath": "resourceFile817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile818", + "filePath": "resourceFile818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile819", + "filePath": "resourceFile819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile820", + "filePath": "resourceFile820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile821", + "filePath": "resourceFile821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile822", + "filePath": "resourceFile822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile823", + "filePath": "resourceFile823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile824", + "filePath": "resourceFile824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile825", + "filePath": "resourceFile825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile826", + "filePath": "resourceFile826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile827", + "filePath": "resourceFile827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile828", + "filePath": "resourceFile828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile829", + "filePath": "resourceFile829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile830", + "filePath": "resourceFile830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile831", + "filePath": "resourceFile831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile832", + "filePath": "resourceFile832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile833", + "filePath": "resourceFile833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile834", + "filePath": "resourceFile834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile835", + "filePath": "resourceFile835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile836", + "filePath": "resourceFile836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile837", + "filePath": "resourceFile837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile838", + "filePath": "resourceFile838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile839", + "filePath": "resourceFile839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile840", + "filePath": "resourceFile840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile841", + "filePath": "resourceFile841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile842", + "filePath": "resourceFile842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile843", + "filePath": "resourceFile843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile844", + "filePath": "resourceFile844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile845", + "filePath": "resourceFile845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile846", + "filePath": "resourceFile846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile847", + "filePath": "resourceFile847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile848", + "filePath": "resourceFile848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile849", + "filePath": "resourceFile849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile850", + "filePath": "resourceFile850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile851", + "filePath": "resourceFile851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile852", + "filePath": "resourceFile852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile853", + "filePath": "resourceFile853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile854", + "filePath": "resourceFile854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile855", + "filePath": "resourceFile855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile856", + "filePath": "resourceFile856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile857", + "filePath": "resourceFile857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile858", + "filePath": "resourceFile858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile859", + "filePath": "resourceFile859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile860", + "filePath": "resourceFile860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile861", + "filePath": "resourceFile861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile862", + "filePath": "resourceFile862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile863", + "filePath": "resourceFile863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile864", + "filePath": "resourceFile864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile865", + "filePath": "resourceFile865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile866", + "filePath": "resourceFile866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile867", + "filePath": "resourceFile867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile868", + "filePath": "resourceFile868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile869", + "filePath": "resourceFile869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile870", + "filePath": "resourceFile870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile871", + "filePath": "resourceFile871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile872", + "filePath": "resourceFile872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile873", + "filePath": "resourceFile873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile874", + "filePath": "resourceFile874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile875", + "filePath": "resourceFile875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile876", + "filePath": "resourceFile876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile877", + "filePath": "resourceFile877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile878", + "filePath": "resourceFile878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile879", + "filePath": "resourceFile879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile880", + "filePath": "resourceFile880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile881", + "filePath": "resourceFile881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile882", + "filePath": "resourceFile882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile883", + "filePath": "resourceFile883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile884", + "filePath": "resourceFile884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile885", + "filePath": "resourceFile885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile886", + "filePath": "resourceFile886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile887", + "filePath": "resourceFile887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile888", + "filePath": "resourceFile888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile889", + "filePath": "resourceFile889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile890", + "filePath": "resourceFile890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile891", + "filePath": "resourceFile891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile892", + "filePath": "resourceFile892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile893", + "filePath": "resourceFile893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile894", + "filePath": "resourceFile894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile895", + "filePath": "resourceFile895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile896", + "filePath": "resourceFile896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile897", + "filePath": "resourceFile897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile898", + "filePath": "resourceFile898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile899", + "filePath": "resourceFile899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile900", + "filePath": "resourceFile900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile901", + "filePath": "resourceFile901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile902", + "filePath": "resourceFile902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile903", + "filePath": "resourceFile903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile904", + "filePath": "resourceFile904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile905", + "filePath": "resourceFile905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile906", + "filePath": "resourceFile906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile907", + "filePath": "resourceFile907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile908", + "filePath": "resourceFile908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile909", + "filePath": "resourceFile909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile910", + "filePath": "resourceFile910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile911", + "filePath": "resourceFile911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile912", + "filePath": "resourceFile912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile913", + "filePath": "resourceFile913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile914", + "filePath": "resourceFile914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile915", + "filePath": "resourceFile915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile916", + "filePath": "resourceFile916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile917", + "filePath": "resourceFile917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile918", + "filePath": "resourceFile918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile919", + "filePath": "resourceFile919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile920", + "filePath": "resourceFile920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile921", + "filePath": "resourceFile921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile922", + "filePath": "resourceFile922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile923", + "filePath": "resourceFile923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile924", + "filePath": "resourceFile924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile925", + "filePath": "resourceFile925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile926", + "filePath": "resourceFile926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile927", + "filePath": "resourceFile927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile928", + "filePath": "resourceFile928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile929", + "filePath": "resourceFile929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile930", + "filePath": "resourceFile930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile931", + "filePath": "resourceFile931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile932", + "filePath": "resourceFile932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile933", + "filePath": "resourceFile933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile934", + "filePath": "resourceFile934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile935", + "filePath": "resourceFile935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile936", + "filePath": "resourceFile936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile937", + "filePath": "resourceFile937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile938", + "filePath": "resourceFile938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile939", + "filePath": "resourceFile939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile940", + "filePath": "resourceFile940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile941", + "filePath": "resourceFile941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile942", + "filePath": "resourceFile942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile943", + "filePath": "resourceFile943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile944", + "filePath": "resourceFile944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile945", + "filePath": "resourceFile945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile946", + "filePath": "resourceFile946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile947", + "filePath": "resourceFile947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile948", + "filePath": "resourceFile948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile949", + "filePath": "resourceFile949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile950", + "filePath": "resourceFile950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile951", + "filePath": "resourceFile951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile952", + "filePath": "resourceFile952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile953", + "filePath": "resourceFile953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile954", + "filePath": "resourceFile954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile955", + "filePath": "resourceFile955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile956", + "filePath": "resourceFile956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile957", + "filePath": "resourceFile957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile958", + "filePath": "resourceFile958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile959", + "filePath": "resourceFile959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile960", + "filePath": "resourceFile960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile961", + "filePath": "resourceFile961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile962", + "filePath": "resourceFile962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile963", + "filePath": "resourceFile963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile964", + "filePath": "resourceFile964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile965", + "filePath": "resourceFile965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile966", + "filePath": "resourceFile966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile967", + "filePath": "resourceFile967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile968", + "filePath": "resourceFile968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile969", + "filePath": "resourceFile969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile970", + "filePath": "resourceFile970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile971", + "filePath": "resourceFile971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile972", + "filePath": "resourceFile972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile973", + "filePath": "resourceFile973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile974", + "filePath": "resourceFile974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile975", + "filePath": "resourceFile975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile976", + "filePath": "resourceFile976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile977", + "filePath": "resourceFile977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile978", + "filePath": "resourceFile978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile979", + "filePath": "resourceFile979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile980", + "filePath": "resourceFile980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile981", + "filePath": "resourceFile981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile982", + "filePath": "resourceFile982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile983", + "filePath": "resourceFile983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile984", + "filePath": "resourceFile984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile985", + "filePath": "resourceFile985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile986", + "filePath": "resourceFile986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile987", + "filePath": "resourceFile987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile988", + "filePath": "resourceFile988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile989", + "filePath": "resourceFile989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile990", + "filePath": "resourceFile990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile991", + "filePath": "resourceFile991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile992", + "filePath": "resourceFile992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile993", + "filePath": "resourceFile993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile994", + "filePath": "resourceFile994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile995", + "filePath": "resourceFile995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile996", + "filePath": "resourceFile996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile997", + "filePath": "resourceFile997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile998", + "filePath": "resourceFile998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile999", + "filePath": "resourceFile999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1000", + "filePath": "resourceFile1000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1001", + "filePath": "resourceFile1001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1002", + "filePath": "resourceFile1002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1003", + "filePath": "resourceFile1003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1004", + "filePath": "resourceFile1004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1005", + "filePath": "resourceFile1005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1006", + "filePath": "resourceFile1006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1007", + "filePath": "resourceFile1007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1008", + "filePath": "resourceFile1008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1009", + "filePath": "resourceFile1009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1010", + "filePath": "resourceFile1010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1011", + "filePath": "resourceFile1011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1012", + "filePath": "resourceFile1012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1013", + "filePath": "resourceFile1013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1014", + "filePath": "resourceFile1014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1015", + "filePath": "resourceFile1015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1016", + "filePath": "resourceFile1016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1017", + "filePath": "resourceFile1017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1018", + "filePath": "resourceFile1018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1019", + "filePath": "resourceFile1019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1020", + "filePath": "resourceFile1020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1021", + "filePath": "resourceFile1021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1022", + "filePath": "resourceFile1022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1023", + "filePath": "resourceFile1023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1024", + "filePath": "resourceFile1024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1025", + "filePath": "resourceFile1025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1026", + "filePath": "resourceFile1026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1027", + "filePath": "resourceFile1027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1028", + "filePath": "resourceFile1028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1029", + "filePath": "resourceFile1029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1030", + "filePath": "resourceFile1030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1031", + "filePath": "resourceFile1031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1032", + "filePath": "resourceFile1032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1033", + "filePath": "resourceFile1033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1034", + "filePath": "resourceFile1034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1035", + "filePath": "resourceFile1035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1036", + "filePath": "resourceFile1036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1037", + "filePath": "resourceFile1037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1038", + "filePath": "resourceFile1038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1039", + "filePath": "resourceFile1039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1040", + "filePath": "resourceFile1040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1041", + "filePath": "resourceFile1041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1042", + "filePath": "resourceFile1042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1043", + "filePath": "resourceFile1043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1044", + "filePath": "resourceFile1044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1045", + "filePath": "resourceFile1045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1046", + "filePath": "resourceFile1046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1047", + "filePath": "resourceFile1047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1048", + "filePath": "resourceFile1048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1049", + "filePath": "resourceFile1049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1050", + "filePath": "resourceFile1050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1051", + "filePath": "resourceFile1051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1052", + "filePath": "resourceFile1052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1053", + "filePath": "resourceFile1053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1054", + "filePath": "resourceFile1054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1055", + "filePath": "resourceFile1055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1056", + "filePath": "resourceFile1056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1057", + "filePath": "resourceFile1057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1058", + "filePath": "resourceFile1058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1059", + "filePath": "resourceFile1059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1060", + "filePath": "resourceFile1060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1061", + "filePath": "resourceFile1061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1062", + "filePath": "resourceFile1062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1063", + "filePath": "resourceFile1063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1064", + "filePath": "resourceFile1064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1065", + "filePath": "resourceFile1065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1066", + "filePath": "resourceFile1066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1067", + "filePath": "resourceFile1067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1068", + "filePath": "resourceFile1068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1069", + "filePath": "resourceFile1069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1070", + "filePath": "resourceFile1070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1071", + "filePath": "resourceFile1071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1072", + "filePath": "resourceFile1072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1073", + "filePath": "resourceFile1073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1074", + "filePath": "resourceFile1074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1075", + "filePath": "resourceFile1075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1076", + "filePath": "resourceFile1076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1077", + "filePath": "resourceFile1077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1078", + "filePath": "resourceFile1078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1079", + "filePath": "resourceFile1079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1080", + "filePath": "resourceFile1080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1081", + "filePath": "resourceFile1081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1082", + "filePath": "resourceFile1082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1083", + "filePath": "resourceFile1083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1084", + "filePath": "resourceFile1084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1085", + "filePath": "resourceFile1085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1086", + "filePath": "resourceFile1086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1087", + "filePath": "resourceFile1087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1088", + "filePath": "resourceFile1088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1089", + "filePath": "resourceFile1089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1090", + "filePath": "resourceFile1090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1091", + "filePath": "resourceFile1091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1092", + "filePath": "resourceFile1092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1093", + "filePath": "resourceFile1093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1094", + "filePath": "resourceFile1094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1095", + "filePath": "resourceFile1095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1096", + "filePath": "resourceFile1096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1097", + "filePath": "resourceFile1097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1098", + "filePath": "resourceFile1098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1099", + "filePath": "resourceFile1099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1100", + "filePath": "resourceFile1100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1101", + "filePath": "resourceFile1101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1102", + "filePath": "resourceFile1102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1103", + "filePath": "resourceFile1103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1104", + "filePath": "resourceFile1104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1105", + "filePath": "resourceFile1105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1106", + "filePath": "resourceFile1106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1107", + "filePath": "resourceFile1107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1108", + "filePath": "resourceFile1108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1109", + "filePath": "resourceFile1109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1110", + "filePath": "resourceFile1110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1111", + "filePath": "resourceFile1111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1112", + "filePath": "resourceFile1112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1113", + "filePath": "resourceFile1113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1114", + "filePath": "resourceFile1114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1115", + "filePath": "resourceFile1115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1116", + "filePath": "resourceFile1116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1117", + "filePath": "resourceFile1117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1118", + "filePath": "resourceFile1118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1119", + "filePath": "resourceFile1119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1120", + "filePath": "resourceFile1120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1121", + "filePath": "resourceFile1121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1122", + "filePath": "resourceFile1122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1123", + "filePath": "resourceFile1123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1124", + "filePath": "resourceFile1124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1125", + "filePath": "resourceFile1125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1126", + "filePath": "resourceFile1126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1127", + "filePath": "resourceFile1127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1128", + "filePath": "resourceFile1128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1129", + "filePath": "resourceFile1129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1130", + "filePath": "resourceFile1130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1131", + "filePath": "resourceFile1131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1132", + "filePath": "resourceFile1132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1133", + "filePath": "resourceFile1133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1134", + "filePath": "resourceFile1134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1135", + "filePath": "resourceFile1135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1136", + "filePath": "resourceFile1136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1137", + "filePath": "resourceFile1137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1138", + "filePath": "resourceFile1138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1139", + "filePath": "resourceFile1139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1140", + "filePath": "resourceFile1140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1141", + "filePath": "resourceFile1141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1142", + "filePath": "resourceFile1142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1143", + "filePath": "resourceFile1143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1144", + "filePath": "resourceFile1144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1145", + "filePath": "resourceFile1145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1146", + "filePath": "resourceFile1146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1147", + "filePath": "resourceFile1147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1148", + "filePath": "resourceFile1148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1149", + "filePath": "resourceFile1149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1150", + "filePath": "resourceFile1150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1151", + "filePath": "resourceFile1151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1152", + "filePath": "resourceFile1152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1153", + "filePath": "resourceFile1153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1154", + "filePath": "resourceFile1154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1155", + "filePath": "resourceFile1155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1156", + "filePath": "resourceFile1156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1157", + "filePath": "resourceFile1157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1158", + "filePath": "resourceFile1158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1159", + "filePath": "resourceFile1159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1160", + "filePath": "resourceFile1160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1161", + "filePath": "resourceFile1161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1162", + "filePath": "resourceFile1162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1163", + "filePath": "resourceFile1163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1164", + "filePath": "resourceFile1164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1165", + "filePath": "resourceFile1165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1166", + "filePath": "resourceFile1166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1167", + "filePath": "resourceFile1167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1168", + "filePath": "resourceFile1168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1169", + "filePath": "resourceFile1169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1170", + "filePath": "resourceFile1170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1171", + "filePath": "resourceFile1171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1172", + "filePath": "resourceFile1172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1173", + "filePath": "resourceFile1173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1174", + "filePath": "resourceFile1174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1175", + "filePath": "resourceFile1175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1176", + "filePath": "resourceFile1176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1177", + "filePath": "resourceFile1177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1178", + "filePath": "resourceFile1178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1179", + "filePath": "resourceFile1179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1180", + "filePath": "resourceFile1180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1181", + "filePath": "resourceFile1181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1182", + "filePath": "resourceFile1182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1183", + "filePath": "resourceFile1183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1184", + "filePath": "resourceFile1184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1185", + "filePath": "resourceFile1185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1186", + "filePath": "resourceFile1186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1187", + "filePath": "resourceFile1187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1188", + "filePath": "resourceFile1188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1189", + "filePath": "resourceFile1189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1190", + "filePath": "resourceFile1190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1191", + "filePath": "resourceFile1191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1192", + "filePath": "resourceFile1192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1193", + "filePath": "resourceFile1193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1194", + "filePath": "resourceFile1194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1195", + "filePath": "resourceFile1195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1196", + "filePath": "resourceFile1196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1197", + "filePath": "resourceFile1197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1198", + "filePath": "resourceFile1198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1199", + "filePath": "resourceFile1199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1200", + "filePath": "resourceFile1200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1201", + "filePath": "resourceFile1201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1202", + "filePath": "resourceFile1202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1203", + "filePath": "resourceFile1203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1204", + "filePath": "resourceFile1204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1205", + "filePath": "resourceFile1205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1206", + "filePath": "resourceFile1206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1207", + "filePath": "resourceFile1207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1208", + "filePath": "resourceFile1208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1209", + "filePath": "resourceFile1209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1210", + "filePath": "resourceFile1210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1211", + "filePath": "resourceFile1211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1212", + "filePath": "resourceFile1212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1213", + "filePath": "resourceFile1213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1214", + "filePath": "resourceFile1214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1215", + "filePath": "resourceFile1215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1216", + "filePath": "resourceFile1216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1217", + "filePath": "resourceFile1217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1218", + "filePath": "resourceFile1218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1219", + "filePath": "resourceFile1219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1220", + "filePath": "resourceFile1220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1221", + "filePath": "resourceFile1221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1222", + "filePath": "resourceFile1222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1223", + "filePath": "resourceFile1223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1224", + "filePath": "resourceFile1224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1225", + "filePath": "resourceFile1225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1226", + "filePath": "resourceFile1226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1227", + "filePath": "resourceFile1227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1228", + "filePath": "resourceFile1228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1229", + "filePath": "resourceFile1229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1230", + "filePath": "resourceFile1230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1231", + "filePath": "resourceFile1231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1232", + "filePath": "resourceFile1232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1233", + "filePath": "resourceFile1233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1234", + "filePath": "resourceFile1234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1235", + "filePath": "resourceFile1235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1236", + "filePath": "resourceFile1236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1237", + "filePath": "resourceFile1237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1238", + "filePath": "resourceFile1238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1239", + "filePath": "resourceFile1239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1240", + "filePath": "resourceFile1240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1241", + "filePath": "resourceFile1241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1242", + "filePath": "resourceFile1242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1243", + "filePath": "resourceFile1243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1244", + "filePath": "resourceFile1244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1245", + "filePath": "resourceFile1245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1246", + "filePath": "resourceFile1246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1247", + "filePath": "resourceFile1247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1248", + "filePath": "resourceFile1248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1249", + "filePath": "resourceFile1249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1250", + "filePath": "resourceFile1250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1251", + "filePath": "resourceFile1251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1252", + "filePath": "resourceFile1252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1253", + "filePath": "resourceFile1253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1254", + "filePath": "resourceFile1254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1255", + "filePath": "resourceFile1255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1256", + "filePath": "resourceFile1256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1257", + "filePath": "resourceFile1257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1258", + "filePath": "resourceFile1258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1259", + "filePath": "resourceFile1259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1260", + "filePath": "resourceFile1260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1261", + "filePath": "resourceFile1261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1262", + "filePath": "resourceFile1262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1263", + "filePath": "resourceFile1263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1264", + "filePath": "resourceFile1264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1265", + "filePath": "resourceFile1265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1266", + "filePath": "resourceFile1266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1267", + "filePath": "resourceFile1267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1268", + "filePath": "resourceFile1268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1269", + "filePath": "resourceFile1269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1270", + "filePath": "resourceFile1270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1271", + "filePath": "resourceFile1271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1272", + "filePath": "resourceFile1272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1273", + "filePath": "resourceFile1273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1274", + "filePath": "resourceFile1274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1275", + "filePath": "resourceFile1275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1276", + "filePath": "resourceFile1276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1277", + "filePath": "resourceFile1277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1278", + "filePath": "resourceFile1278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1279", + "filePath": "resourceFile1279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1280", + "filePath": "resourceFile1280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1281", + "filePath": "resourceFile1281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1282", + "filePath": "resourceFile1282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1283", + "filePath": "resourceFile1283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1284", + "filePath": "resourceFile1284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1285", + "filePath": "resourceFile1285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1286", + "filePath": "resourceFile1286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1287", + "filePath": "resourceFile1287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1288", + "filePath": "resourceFile1288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1289", + "filePath": "resourceFile1289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1290", + "filePath": "resourceFile1290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1291", + "filePath": "resourceFile1291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1292", + "filePath": "resourceFile1292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1293", + "filePath": "resourceFile1293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1294", + "filePath": "resourceFile1294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1295", + "filePath": "resourceFile1295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1296", + "filePath": "resourceFile1296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1297", + "filePath": "resourceFile1297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1298", + "filePath": "resourceFile1298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1299", + "filePath": "resourceFile1299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1300", + "filePath": "resourceFile1300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1301", + "filePath": "resourceFile1301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1302", + "filePath": "resourceFile1302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1303", + "filePath": "resourceFile1303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1304", + "filePath": "resourceFile1304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1305", + "filePath": "resourceFile1305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1306", + "filePath": "resourceFile1306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1307", + "filePath": "resourceFile1307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1308", + "filePath": "resourceFile1308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1309", + "filePath": "resourceFile1309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1310", + "filePath": "resourceFile1310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1311", + "filePath": "resourceFile1311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1312", + "filePath": "resourceFile1312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1313", + "filePath": "resourceFile1313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1314", + "filePath": "resourceFile1314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1315", + "filePath": "resourceFile1315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1316", + "filePath": "resourceFile1316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1317", + "filePath": "resourceFile1317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1318", + "filePath": "resourceFile1318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1319", + "filePath": "resourceFile1319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1320", + "filePath": "resourceFile1320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1321", + "filePath": "resourceFile1321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1322", + "filePath": "resourceFile1322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1323", + "filePath": "resourceFile1323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1324", + "filePath": "resourceFile1324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1325", + "filePath": "resourceFile1325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1326", + "filePath": "resourceFile1326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1327", + "filePath": "resourceFile1327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1328", + "filePath": "resourceFile1328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1329", + "filePath": "resourceFile1329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1330", + "filePath": "resourceFile1330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1331", + "filePath": "resourceFile1331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1332", + "filePath": "resourceFile1332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1333", + "filePath": "resourceFile1333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1334", + "filePath": "resourceFile1334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1335", + "filePath": "resourceFile1335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1336", + "filePath": "resourceFile1336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1337", + "filePath": "resourceFile1337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1338", + "filePath": "resourceFile1338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1339", + "filePath": "resourceFile1339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1340", + "filePath": "resourceFile1340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1341", + "filePath": "resourceFile1341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1342", + "filePath": "resourceFile1342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1343", + "filePath": "resourceFile1343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1344", + "filePath": "resourceFile1344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1345", + "filePath": "resourceFile1345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1346", + "filePath": "resourceFile1346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1347", + "filePath": "resourceFile1347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1348", + "filePath": "resourceFile1348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1349", + "filePath": "resourceFile1349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1350", + "filePath": "resourceFile1350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1351", + "filePath": "resourceFile1351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1352", + "filePath": "resourceFile1352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1353", + "filePath": "resourceFile1353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1354", + "filePath": "resourceFile1354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1355", + "filePath": "resourceFile1355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1356", + "filePath": "resourceFile1356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1357", + "filePath": "resourceFile1357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1358", + "filePath": "resourceFile1358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1359", + "filePath": "resourceFile1359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1360", + "filePath": "resourceFile1360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1361", + "filePath": "resourceFile1361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1362", + "filePath": "resourceFile1362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1363", + "filePath": "resourceFile1363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1364", + "filePath": "resourceFile1364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1365", + "filePath": "resourceFile1365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1366", + "filePath": "resourceFile1366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1367", + "filePath": "resourceFile1367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1368", + "filePath": "resourceFile1368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1369", + "filePath": "resourceFile1369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1370", + "filePath": "resourceFile1370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1371", + "filePath": "resourceFile1371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1372", + "filePath": "resourceFile1372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1373", + "filePath": "resourceFile1373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1374", + "filePath": "resourceFile1374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1375", + "filePath": "resourceFile1375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1376", + "filePath": "resourceFile1376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1377", + "filePath": "resourceFile1377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1378", + "filePath": "resourceFile1378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1379", + "filePath": "resourceFile1379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1380", + "filePath": "resourceFile1380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1381", + "filePath": "resourceFile1381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1382", + "filePath": "resourceFile1382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1383", + "filePath": "resourceFile1383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1384", + "filePath": "resourceFile1384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1385", + "filePath": "resourceFile1385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1386", + "filePath": "resourceFile1386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1387", + "filePath": "resourceFile1387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1388", + "filePath": "resourceFile1388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1389", + "filePath": "resourceFile1389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1390", + "filePath": "resourceFile1390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1391", + "filePath": "resourceFile1391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1392", + "filePath": "resourceFile1392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1393", + "filePath": "resourceFile1393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1394", + "filePath": "resourceFile1394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1395", + "filePath": "resourceFile1395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1396", + "filePath": "resourceFile1396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1397", + "filePath": "resourceFile1397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1398", + "filePath": "resourceFile1398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1399", + "filePath": "resourceFile1399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1400", + "filePath": "resourceFile1400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1401", + "filePath": "resourceFile1401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1402", + "filePath": "resourceFile1402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1403", + "filePath": "resourceFile1403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1404", + "filePath": "resourceFile1404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1405", + "filePath": "resourceFile1405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1406", + "filePath": "resourceFile1406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1407", + "filePath": "resourceFile1407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1408", + "filePath": "resourceFile1408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1409", + "filePath": "resourceFile1409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1410", + "filePath": "resourceFile1410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1411", + "filePath": "resourceFile1411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1412", + "filePath": "resourceFile1412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1413", + "filePath": "resourceFile1413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1414", + "filePath": "resourceFile1414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1415", + "filePath": "resourceFile1415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1416", + "filePath": "resourceFile1416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1417", + "filePath": "resourceFile1417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1418", + "filePath": "resourceFile1418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1419", + "filePath": "resourceFile1419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1420", + "filePath": "resourceFile1420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1421", + "filePath": "resourceFile1421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1422", + "filePath": "resourceFile1422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1423", + "filePath": "resourceFile1423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1424", + "filePath": "resourceFile1424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1425", + "filePath": "resourceFile1425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1426", + "filePath": "resourceFile1426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1427", + "filePath": "resourceFile1427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1428", + "filePath": "resourceFile1428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1429", + "filePath": "resourceFile1429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1430", + "filePath": "resourceFile1430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1431", + "filePath": "resourceFile1431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1432", + "filePath": "resourceFile1432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1433", + "filePath": "resourceFile1433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1434", + "filePath": "resourceFile1434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1435", + "filePath": "resourceFile1435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1436", + "filePath": "resourceFile1436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1437", + "filePath": "resourceFile1437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1438", + "filePath": "resourceFile1438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1439", + "filePath": "resourceFile1439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1440", + "filePath": "resourceFile1440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1441", + "filePath": "resourceFile1441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1442", + "filePath": "resourceFile1442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1443", + "filePath": "resourceFile1443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1444", + "filePath": "resourceFile1444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1445", + "filePath": "resourceFile1445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1446", + "filePath": "resourceFile1446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1447", + "filePath": "resourceFile1447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1448", + "filePath": "resourceFile1448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1449", + "filePath": "resourceFile1449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1450", + "filePath": "resourceFile1450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1451", + "filePath": "resourceFile1451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1452", + "filePath": "resourceFile1452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1453", + "filePath": "resourceFile1453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1454", + "filePath": "resourceFile1454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1455", + "filePath": "resourceFile1455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1456", + "filePath": "resourceFile1456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1457", + "filePath": "resourceFile1457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1458", + "filePath": "resourceFile1458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1459", + "filePath": "resourceFile1459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1460", + "filePath": "resourceFile1460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1461", + "filePath": "resourceFile1461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1462", + "filePath": "resourceFile1462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1463", + "filePath": "resourceFile1463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1464", + "filePath": "resourceFile1464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1465", + "filePath": "resourceFile1465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1466", + "filePath": "resourceFile1466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1467", + "filePath": "resourceFile1467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1468", + "filePath": "resourceFile1468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1469", + "filePath": "resourceFile1469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1470", + "filePath": "resourceFile1470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1471", + "filePath": "resourceFile1471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1472", + "filePath": "resourceFile1472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1473", + "filePath": "resourceFile1473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1474", + "filePath": "resourceFile1474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1475", + "filePath": "resourceFile1475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1476", + "filePath": "resourceFile1476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1477", + "filePath": "resourceFile1477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1478", + "filePath": "resourceFile1478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1479", + "filePath": "resourceFile1479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1480", + "filePath": "resourceFile1480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1481", + "filePath": "resourceFile1481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1482", + "filePath": "resourceFile1482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1483", + "filePath": "resourceFile1483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1484", + "filePath": "resourceFile1484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1485", + "filePath": "resourceFile1485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1486", + "filePath": "resourceFile1486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1487", + "filePath": "resourceFile1487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1488", + "filePath": "resourceFile1488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1489", + "filePath": "resourceFile1489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1490", + "filePath": "resourceFile1490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1491", + "filePath": "resourceFile1491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1492", + "filePath": "resourceFile1492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1493", + "filePath": "resourceFile1493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1494", + "filePath": "resourceFile1494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1495", + "filePath": "resourceFile1495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1496", + "filePath": "resourceFile1496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1497", + "filePath": "resourceFile1497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1498", + "filePath": "resourceFile1498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1499", + "filePath": "resourceFile1499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1500", + "filePath": "resourceFile1500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1501", + "filePath": "resourceFile1501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1502", + "filePath": "resourceFile1502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1503", + "filePath": "resourceFile1503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1504", + "filePath": "resourceFile1504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1505", + "filePath": "resourceFile1505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1506", + "filePath": "resourceFile1506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1507", + "filePath": "resourceFile1507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1508", + "filePath": "resourceFile1508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1509", + "filePath": "resourceFile1509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1510", + "filePath": "resourceFile1510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1511", + "filePath": "resourceFile1511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1512", + "filePath": "resourceFile1512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1513", + "filePath": "resourceFile1513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1514", + "filePath": "resourceFile1514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1515", + "filePath": "resourceFile1515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1516", + "filePath": "resourceFile1516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1517", + "filePath": "resourceFile1517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1518", + "filePath": "resourceFile1518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1519", + "filePath": "resourceFile1519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1520", + "filePath": "resourceFile1520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1521", + "filePath": "resourceFile1521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1522", + "filePath": "resourceFile1522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1523", + "filePath": "resourceFile1523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1524", + "filePath": "resourceFile1524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1525", + "filePath": "resourceFile1525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1526", + "filePath": "resourceFile1526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1527", + "filePath": "resourceFile1527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1528", + "filePath": "resourceFile1528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1529", + "filePath": "resourceFile1529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1530", + "filePath": "resourceFile1530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1531", + "filePath": "resourceFile1531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1532", + "filePath": "resourceFile1532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1533", + "filePath": "resourceFile1533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1534", + "filePath": "resourceFile1534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1535", + "filePath": "resourceFile1535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1536", + "filePath": "resourceFile1536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1537", + "filePath": "resourceFile1537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1538", + "filePath": "resourceFile1538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1539", + "filePath": "resourceFile1539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1540", + "filePath": "resourceFile1540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1541", + "filePath": "resourceFile1541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1542", + "filePath": "resourceFile1542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1543", + "filePath": "resourceFile1543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1544", + "filePath": "resourceFile1544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1545", + "filePath": "resourceFile1545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1546", + "filePath": "resourceFile1546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1547", + "filePath": "resourceFile1547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1548", + "filePath": "resourceFile1548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1549", + "filePath": "resourceFile1549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1550", + "filePath": "resourceFile1550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1551", + "filePath": "resourceFile1551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1552", + "filePath": "resourceFile1552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1553", + "filePath": "resourceFile1553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1554", + "filePath": "resourceFile1554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1555", + "filePath": "resourceFile1555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1556", + "filePath": "resourceFile1556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1557", + "filePath": "resourceFile1557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1558", + "filePath": "resourceFile1558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1559", + "filePath": "resourceFile1559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1560", + "filePath": "resourceFile1560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1561", + "filePath": "resourceFile1561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1562", + "filePath": "resourceFile1562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1563", + "filePath": "resourceFile1563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1564", + "filePath": "resourceFile1564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1565", + "filePath": "resourceFile1565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1566", + "filePath": "resourceFile1566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1567", + "filePath": "resourceFile1567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1568", + "filePath": "resourceFile1568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1569", + "filePath": "resourceFile1569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1570", + "filePath": "resourceFile1570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1571", + "filePath": "resourceFile1571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1572", + "filePath": "resourceFile1572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1573", + "filePath": "resourceFile1573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1574", + "filePath": "resourceFile1574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1575", + "filePath": "resourceFile1575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1576", + "filePath": "resourceFile1576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1577", + "filePath": "resourceFile1577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1578", + "filePath": "resourceFile1578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1579", + "filePath": "resourceFile1579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1580", + "filePath": "resourceFile1580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1581", + "filePath": "resourceFile1581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1582", + "filePath": "resourceFile1582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1583", + "filePath": "resourceFile1583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1584", + "filePath": "resourceFile1584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1585", + "filePath": "resourceFile1585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1586", + "filePath": "resourceFile1586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1587", + "filePath": "resourceFile1587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1588", + "filePath": "resourceFile1588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1589", + "filePath": "resourceFile1589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1590", + "filePath": "resourceFile1590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1591", + "filePath": "resourceFile1591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1592", + "filePath": "resourceFile1592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1593", + "filePath": "resourceFile1593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1594", + "filePath": "resourceFile1594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1595", + "filePath": "resourceFile1595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1596", + "filePath": "resourceFile1596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1597", + "filePath": "resourceFile1597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1598", + "filePath": "resourceFile1598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1599", + "filePath": "resourceFile1599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1600", + "filePath": "resourceFile1600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1601", + "filePath": "resourceFile1601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1602", + "filePath": "resourceFile1602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1603", + "filePath": "resourceFile1603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1604", + "filePath": "resourceFile1604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1605", + "filePath": "resourceFile1605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1606", + "filePath": "resourceFile1606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1607", + "filePath": "resourceFile1607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1608", + "filePath": "resourceFile1608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1609", + "filePath": "resourceFile1609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1610", + "filePath": "resourceFile1610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1611", + "filePath": "resourceFile1611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1612", + "filePath": "resourceFile1612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1613", + "filePath": "resourceFile1613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1614", + "filePath": "resourceFile1614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1615", + "filePath": "resourceFile1615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1616", + "filePath": "resourceFile1616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1617", + "filePath": "resourceFile1617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1618", + "filePath": "resourceFile1618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1619", + "filePath": "resourceFile1619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1620", + "filePath": "resourceFile1620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1621", + "filePath": "resourceFile1621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1622", + "filePath": "resourceFile1622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1623", + "filePath": "resourceFile1623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1624", + "filePath": "resourceFile1624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1625", + "filePath": "resourceFile1625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1626", + "filePath": "resourceFile1626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1627", + "filePath": "resourceFile1627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1628", + "filePath": "resourceFile1628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1629", + "filePath": "resourceFile1629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1630", + "filePath": "resourceFile1630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1631", + "filePath": "resourceFile1631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1632", + "filePath": "resourceFile1632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1633", + "filePath": "resourceFile1633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1634", + "filePath": "resourceFile1634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1635", + "filePath": "resourceFile1635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1636", + "filePath": "resourceFile1636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1637", + "filePath": "resourceFile1637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1638", + "filePath": "resourceFile1638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1639", + "filePath": "resourceFile1639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1640", + "filePath": "resourceFile1640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1641", + "filePath": "resourceFile1641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1642", + "filePath": "resourceFile1642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1643", + "filePath": "resourceFile1643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1644", + "filePath": "resourceFile1644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1645", + "filePath": "resourceFile1645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1646", + "filePath": "resourceFile1646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1647", + "filePath": "resourceFile1647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1648", + "filePath": "resourceFile1648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1649", + "filePath": "resourceFile1649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1650", + "filePath": "resourceFile1650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1651", + "filePath": "resourceFile1651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1652", + "filePath": "resourceFile1652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1653", + "filePath": "resourceFile1653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1654", + "filePath": "resourceFile1654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1655", + "filePath": "resourceFile1655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1656", + "filePath": "resourceFile1656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1657", + "filePath": "resourceFile1657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1658", + "filePath": "resourceFile1658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1659", + "filePath": "resourceFile1659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1660", + "filePath": "resourceFile1660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1661", + "filePath": "resourceFile1661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1662", + "filePath": "resourceFile1662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1663", + "filePath": "resourceFile1663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1664", + "filePath": "resourceFile1664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1665", + "filePath": "resourceFile1665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1666", + "filePath": "resourceFile1666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1667", + "filePath": "resourceFile1667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1668", + "filePath": "resourceFile1668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1669", + "filePath": "resourceFile1669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1670", + "filePath": "resourceFile1670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1671", + "filePath": "resourceFile1671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1672", + "filePath": "resourceFile1672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1673", + "filePath": "resourceFile1673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1674", + "filePath": "resourceFile1674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1675", + "filePath": "resourceFile1675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1676", + "filePath": "resourceFile1676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1677", + "filePath": "resourceFile1677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1678", + "filePath": "resourceFile1678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1679", + "filePath": "resourceFile1679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1680", + "filePath": "resourceFile1680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1681", + "filePath": "resourceFile1681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1682", + "filePath": "resourceFile1682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1683", + "filePath": "resourceFile1683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1684", + "filePath": "resourceFile1684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1685", + "filePath": "resourceFile1685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1686", + "filePath": "resourceFile1686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1687", + "filePath": "resourceFile1687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1688", + "filePath": "resourceFile1688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1689", + "filePath": "resourceFile1689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1690", + "filePath": "resourceFile1690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1691", + "filePath": "resourceFile1691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1692", + "filePath": "resourceFile1692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1693", + "filePath": "resourceFile1693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1694", + "filePath": "resourceFile1694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1695", + "filePath": "resourceFile1695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1696", + "filePath": "resourceFile1696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1697", + "filePath": "resourceFile1697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1698", + "filePath": "resourceFile1698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1699", + "filePath": "resourceFile1699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1700", + "filePath": "resourceFile1700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1701", + "filePath": "resourceFile1701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1702", + "filePath": "resourceFile1702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1703", + "filePath": "resourceFile1703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1704", + "filePath": "resourceFile1704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1705", + "filePath": "resourceFile1705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1706", + "filePath": "resourceFile1706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1707", + "filePath": "resourceFile1707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1708", + "filePath": "resourceFile1708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1709", + "filePath": "resourceFile1709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1710", + "filePath": "resourceFile1710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1711", + "filePath": "resourceFile1711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1712", + "filePath": "resourceFile1712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1713", + "filePath": "resourceFile1713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1714", + "filePath": "resourceFile1714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1715", + "filePath": "resourceFile1715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1716", + "filePath": "resourceFile1716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1717", + "filePath": "resourceFile1717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1718", + "filePath": "resourceFile1718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1719", + "filePath": "resourceFile1719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1720", + "filePath": "resourceFile1720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1721", + "filePath": "resourceFile1721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1722", + "filePath": "resourceFile1722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1723", + "filePath": "resourceFile1723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1724", + "filePath": "resourceFile1724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1725", + "filePath": "resourceFile1725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1726", + "filePath": "resourceFile1726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1727", + "filePath": "resourceFile1727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1728", + "filePath": "resourceFile1728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1729", + "filePath": "resourceFile1729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1730", + "filePath": "resourceFile1730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1731", + "filePath": "resourceFile1731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1732", + "filePath": "resourceFile1732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1733", + "filePath": "resourceFile1733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1734", + "filePath": "resourceFile1734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1735", + "filePath": "resourceFile1735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1736", + "filePath": "resourceFile1736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1737", + "filePath": "resourceFile1737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1738", + "filePath": "resourceFile1738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1739", + "filePath": "resourceFile1739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1740", + "filePath": "resourceFile1740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1741", + "filePath": "resourceFile1741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1742", + "filePath": "resourceFile1742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1743", + "filePath": "resourceFile1743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1744", + "filePath": "resourceFile1744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1745", + "filePath": "resourceFile1745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1746", + "filePath": "resourceFile1746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1747", + "filePath": "resourceFile1747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1748", + "filePath": "resourceFile1748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1749", + "filePath": "resourceFile1749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1750", + "filePath": "resourceFile1750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1751", + "filePath": "resourceFile1751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1752", + "filePath": "resourceFile1752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1753", + "filePath": "resourceFile1753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1754", + "filePath": "resourceFile1754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1755", + "filePath": "resourceFile1755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1756", + "filePath": "resourceFile1756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1757", + "filePath": "resourceFile1757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1758", + "filePath": "resourceFile1758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1759", + "filePath": "resourceFile1759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1760", + "filePath": "resourceFile1760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1761", + "filePath": "resourceFile1761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1762", + "filePath": "resourceFile1762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1763", + "filePath": "resourceFile1763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1764", + "filePath": "resourceFile1764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1765", + "filePath": "resourceFile1765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1766", + "filePath": "resourceFile1766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1767", + "filePath": "resourceFile1767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1768", + "filePath": "resourceFile1768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1769", + "filePath": "resourceFile1769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1770", + "filePath": "resourceFile1770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1771", + "filePath": "resourceFile1771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1772", + "filePath": "resourceFile1772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1773", + "filePath": "resourceFile1773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1774", + "filePath": "resourceFile1774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1775", + "filePath": "resourceFile1775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1776", + "filePath": "resourceFile1776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1777", + "filePath": "resourceFile1777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1778", + "filePath": "resourceFile1778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1779", + "filePath": "resourceFile1779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1780", + "filePath": "resourceFile1780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1781", + "filePath": "resourceFile1781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1782", + "filePath": "resourceFile1782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1783", + "filePath": "resourceFile1783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1784", + "filePath": "resourceFile1784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1785", + "filePath": "resourceFile1785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1786", + "filePath": "resourceFile1786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1787", + "filePath": "resourceFile1787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1788", + "filePath": "resourceFile1788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1789", + "filePath": "resourceFile1789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1790", + "filePath": "resourceFile1790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1791", + "filePath": "resourceFile1791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1792", + "filePath": "resourceFile1792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1793", + "filePath": "resourceFile1793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1794", + "filePath": "resourceFile1794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1795", + "filePath": "resourceFile1795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1796", + "filePath": "resourceFile1796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1797", + "filePath": "resourceFile1797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1798", + "filePath": "resourceFile1798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1799", + "filePath": "resourceFile1799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1800", + "filePath": "resourceFile1800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1801", + "filePath": "resourceFile1801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1802", + "filePath": "resourceFile1802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1803", + "filePath": "resourceFile1803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1804", + "filePath": "resourceFile1804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1805", + "filePath": "resourceFile1805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1806", + "filePath": "resourceFile1806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1807", + "filePath": "resourceFile1807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1808", + "filePath": "resourceFile1808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1809", + "filePath": "resourceFile1809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1810", + "filePath": "resourceFile1810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1811", + "filePath": "resourceFile1811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1812", + "filePath": "resourceFile1812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1813", + "filePath": "resourceFile1813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1814", + "filePath": "resourceFile1814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1815", + "filePath": "resourceFile1815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1816", + "filePath": "resourceFile1816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1817", + "filePath": "resourceFile1817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1818", + "filePath": "resourceFile1818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1819", + "filePath": "resourceFile1819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1820", + "filePath": "resourceFile1820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1821", + "filePath": "resourceFile1821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1822", + "filePath": "resourceFile1822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1823", + "filePath": "resourceFile1823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1824", + "filePath": "resourceFile1824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1825", + "filePath": "resourceFile1825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1826", + "filePath": "resourceFile1826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1827", + "filePath": "resourceFile1827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1828", + "filePath": "resourceFile1828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1829", + "filePath": "resourceFile1829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1830", + "filePath": "resourceFile1830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1831", + "filePath": "resourceFile1831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1832", + "filePath": "resourceFile1832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1833", + "filePath": "resourceFile1833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1834", + "filePath": "resourceFile1834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1835", + "filePath": "resourceFile1835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1836", + "filePath": "resourceFile1836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1837", + "filePath": "resourceFile1837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1838", + "filePath": "resourceFile1838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1839", + "filePath": "resourceFile1839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1840", + "filePath": "resourceFile1840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1841", + "filePath": "resourceFile1841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1842", + "filePath": "resourceFile1842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1843", + "filePath": "resourceFile1843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1844", + "filePath": "resourceFile1844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1845", + "filePath": "resourceFile1845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1846", + "filePath": "resourceFile1846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1847", + "filePath": "resourceFile1847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1848", + "filePath": "resourceFile1848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1849", + "filePath": "resourceFile1849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1850", + "filePath": "resourceFile1850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1851", + "filePath": "resourceFile1851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1852", + "filePath": "resourceFile1852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1853", + "filePath": "resourceFile1853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1854", + "filePath": "resourceFile1854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1855", + "filePath": "resourceFile1855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1856", + "filePath": "resourceFile1856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1857", + "filePath": "resourceFile1857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1858", + "filePath": "resourceFile1858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1859", + "filePath": "resourceFile1859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1860", + "filePath": "resourceFile1860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1861", + "filePath": "resourceFile1861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1862", + "filePath": "resourceFile1862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1863", + "filePath": "resourceFile1863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1864", + "filePath": "resourceFile1864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1865", + "filePath": "resourceFile1865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1866", + "filePath": "resourceFile1866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1867", + "filePath": "resourceFile1867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1868", + "filePath": "resourceFile1868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1869", + "filePath": "resourceFile1869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1870", + "filePath": "resourceFile1870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1871", + "filePath": "resourceFile1871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1872", + "filePath": "resourceFile1872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1873", + "filePath": "resourceFile1873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1874", + "filePath": "resourceFile1874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1875", + "filePath": "resourceFile1875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1876", + "filePath": "resourceFile1876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1877", + "filePath": "resourceFile1877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1878", + "filePath": "resourceFile1878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1879", + "filePath": "resourceFile1879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1880", + "filePath": "resourceFile1880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1881", + "filePath": "resourceFile1881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1882", + "filePath": "resourceFile1882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1883", + "filePath": "resourceFile1883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1884", + "filePath": "resourceFile1884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1885", + "filePath": "resourceFile1885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1886", + "filePath": "resourceFile1886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1887", + "filePath": "resourceFile1887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1888", + "filePath": "resourceFile1888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1889", + "filePath": "resourceFile1889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1890", + "filePath": "resourceFile1890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1891", + "filePath": "resourceFile1891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1892", + "filePath": "resourceFile1892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1893", + "filePath": "resourceFile1893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1894", + "filePath": "resourceFile1894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1895", + "filePath": "resourceFile1895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1896", + "filePath": "resourceFile1896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1897", + "filePath": "resourceFile1897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1898", + "filePath": "resourceFile1898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1899", + "filePath": "resourceFile1899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1900", + "filePath": "resourceFile1900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1901", + "filePath": "resourceFile1901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1902", + "filePath": "resourceFile1902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1903", + "filePath": "resourceFile1903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1904", + "filePath": "resourceFile1904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1905", + "filePath": "resourceFile1905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1906", + "filePath": "resourceFile1906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1907", + "filePath": "resourceFile1907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1908", + "filePath": "resourceFile1908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1909", + "filePath": "resourceFile1909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1910", + "filePath": "resourceFile1910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1911", + "filePath": "resourceFile1911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1912", + "filePath": "resourceFile1912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1913", + "filePath": "resourceFile1913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1914", + "filePath": "resourceFile1914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1915", + "filePath": "resourceFile1915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1916", + "filePath": "resourceFile1916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1917", + "filePath": "resourceFile1917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1918", + "filePath": "resourceFile1918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1919", + "filePath": "resourceFile1919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1920", + "filePath": "resourceFile1920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1921", + "filePath": "resourceFile1921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1922", + "filePath": "resourceFile1922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1923", + "filePath": "resourceFile1923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1924", + "filePath": "resourceFile1924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1925", + "filePath": "resourceFile1925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1926", + "filePath": "resourceFile1926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1927", + "filePath": "resourceFile1927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1928", + "filePath": "resourceFile1928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1929", + "filePath": "resourceFile1929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1930", + "filePath": "resourceFile1930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1931", + "filePath": "resourceFile1931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1932", + "filePath": "resourceFile1932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1933", + "filePath": "resourceFile1933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1934", + "filePath": "resourceFile1934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1935", + "filePath": "resourceFile1935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1936", + "filePath": "resourceFile1936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1937", + "filePath": "resourceFile1937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1938", + "filePath": "resourceFile1938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1939", + "filePath": "resourceFile1939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1940", + "filePath": "resourceFile1940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1941", + "filePath": "resourceFile1941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1942", + "filePath": "resourceFile1942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1943", + "filePath": "resourceFile1943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1944", + "filePath": "resourceFile1944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1945", + "filePath": "resourceFile1945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1946", + "filePath": "resourceFile1946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1947", + "filePath": "resourceFile1947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1948", + "filePath": "resourceFile1948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1949", + "filePath": "resourceFile1949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1950", + "filePath": "resourceFile1950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1951", + "filePath": "resourceFile1951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1952", + "filePath": "resourceFile1952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1953", + "filePath": "resourceFile1953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1954", + "filePath": "resourceFile1954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1955", + "filePath": "resourceFile1955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1956", + "filePath": "resourceFile1956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1957", + "filePath": "resourceFile1957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1958", + "filePath": "resourceFile1958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1959", + "filePath": "resourceFile1959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1960", + "filePath": "resourceFile1960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1961", + "filePath": "resourceFile1961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1962", + "filePath": "resourceFile1962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1963", + "filePath": "resourceFile1963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1964", + "filePath": "resourceFile1964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1965", + "filePath": "resourceFile1965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1966", + "filePath": "resourceFile1966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1967", + "filePath": "resourceFile1967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1968", + "filePath": "resourceFile1968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1969", + "filePath": "resourceFile1969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1970", + "filePath": "resourceFile1970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1971", + "filePath": "resourceFile1971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1972", + "filePath": "resourceFile1972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1973", + "filePath": "resourceFile1973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1974", + "filePath": "resourceFile1974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1975", + "filePath": "resourceFile1975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1976", + "filePath": "resourceFile1976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1977", + "filePath": "resourceFile1977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1978", + "filePath": "resourceFile1978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1979", + "filePath": "resourceFile1979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1980", + "filePath": "resourceFile1980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1981", + "filePath": "resourceFile1981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1982", + "filePath": "resourceFile1982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1983", + "filePath": "resourceFile1983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1984", + "filePath": "resourceFile1984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1985", + "filePath": "resourceFile1985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1986", + "filePath": "resourceFile1986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1987", + "filePath": "resourceFile1987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1988", + "filePath": "resourceFile1988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1989", + "filePath": "resourceFile1989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1990", + "filePath": "resourceFile1990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1991", + "filePath": "resourceFile1991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1992", + "filePath": "resourceFile1992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1993", + "filePath": "resourceFile1993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1994", + "filePath": "resourceFile1994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1995", + "filePath": "resourceFile1995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1996", + "filePath": "resourceFile1996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1997", + "filePath": "resourceFile1997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1998", + "filePath": "resourceFile1998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1999", + "filePath": "resourceFile1999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2000", + "filePath": "resourceFile2000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2001", + "filePath": "resourceFile2001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2002", + "filePath": "resourceFile2002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2003", + "filePath": "resourceFile2003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2004", + "filePath": "resourceFile2004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2005", + "filePath": "resourceFile2005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2006", + "filePath": "resourceFile2006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2007", + "filePath": "resourceFile2007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2008", + "filePath": "resourceFile2008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2009", + "filePath": "resourceFile2009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2010", + "filePath": "resourceFile2010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2011", + "filePath": "resourceFile2011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2012", + "filePath": "resourceFile2012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2013", + "filePath": "resourceFile2013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2014", + "filePath": "resourceFile2014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2015", + "filePath": "resourceFile2015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2016", + "filePath": "resourceFile2016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2017", + "filePath": "resourceFile2017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2018", + "filePath": "resourceFile2018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2019", + "filePath": "resourceFile2019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2020", + "filePath": "resourceFile2020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2021", + "filePath": "resourceFile2021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2022", + "filePath": "resourceFile2022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2023", + "filePath": "resourceFile2023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2024", + "filePath": "resourceFile2024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2025", + "filePath": "resourceFile2025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2026", + "filePath": "resourceFile2026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2027", + "filePath": "resourceFile2027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2028", + "filePath": "resourceFile2028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2029", + "filePath": "resourceFile2029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2030", + "filePath": "resourceFile2030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2031", + "filePath": "resourceFile2031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2032", + "filePath": "resourceFile2032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2033", + "filePath": "resourceFile2033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2034", + "filePath": "resourceFile2034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2035", + "filePath": "resourceFile2035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2036", + "filePath": "resourceFile2036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2037", + "filePath": "resourceFile2037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2038", + "filePath": "resourceFile2038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2039", + "filePath": "resourceFile2039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2040", + "filePath": "resourceFile2040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2041", + "filePath": "resourceFile2041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2042", + "filePath": "resourceFile2042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2043", + "filePath": "resourceFile2043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2044", + "filePath": "resourceFile2044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2045", + "filePath": "resourceFile2045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2046", + "filePath": "resourceFile2046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2047", + "filePath": "resourceFile2047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2048", + "filePath": "resourceFile2048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2049", + "filePath": "resourceFile2049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2050", + "filePath": "resourceFile2050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2051", + "filePath": "resourceFile2051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2052", + "filePath": "resourceFile2052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2053", + "filePath": "resourceFile2053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2054", + "filePath": "resourceFile2054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2055", + "filePath": "resourceFile2055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2056", + "filePath": "resourceFile2056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2057", + "filePath": "resourceFile2057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2058", + "filePath": "resourceFile2058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2059", + "filePath": "resourceFile2059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2060", + "filePath": "resourceFile2060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2061", + "filePath": "resourceFile2061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2062", + "filePath": "resourceFile2062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2063", + "filePath": "resourceFile2063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2064", + "filePath": "resourceFile2064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2065", + "filePath": "resourceFile2065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2066", + "filePath": "resourceFile2066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2067", + "filePath": "resourceFile2067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2068", + "filePath": "resourceFile2068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2069", + "filePath": "resourceFile2069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2070", + "filePath": "resourceFile2070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2071", + "filePath": "resourceFile2071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2072", + "filePath": "resourceFile2072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2073", + "filePath": "resourceFile2073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2074", + "filePath": "resourceFile2074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2075", + "filePath": "resourceFile2075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2076", + "filePath": "resourceFile2076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2077", + "filePath": "resourceFile2077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2078", + "filePath": "resourceFile2078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2079", + "filePath": "resourceFile2079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2080", + "filePath": "resourceFile2080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2081", + "filePath": "resourceFile2081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2082", + "filePath": "resourceFile2082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2083", + "filePath": "resourceFile2083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2084", + "filePath": "resourceFile2084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2085", + "filePath": "resourceFile2085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2086", + "filePath": "resourceFile2086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2087", + "filePath": "resourceFile2087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2088", + "filePath": "resourceFile2088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2089", + "filePath": "resourceFile2089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2090", + "filePath": "resourceFile2090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2091", + "filePath": "resourceFile2091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2092", + "filePath": "resourceFile2092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2093", + "filePath": "resourceFile2093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2094", + "filePath": "resourceFile2094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2095", + "filePath": "resourceFile2095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2096", + "filePath": "resourceFile2096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2097", + "filePath": "resourceFile2097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2098", + "filePath": "resourceFile2098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2099", + "filePath": "resourceFile2099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2100", + "filePath": "resourceFile2100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2101", + "filePath": "resourceFile2101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2102", + "filePath": "resourceFile2102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2103", + "filePath": "resourceFile2103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2104", + "filePath": "resourceFile2104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2105", + "filePath": "resourceFile2105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2106", + "filePath": "resourceFile2106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2107", + "filePath": "resourceFile2107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2108", + "filePath": "resourceFile2108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2109", + "filePath": "resourceFile2109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2110", + "filePath": "resourceFile2110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2111", + "filePath": "resourceFile2111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2112", + "filePath": "resourceFile2112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2113", + "filePath": "resourceFile2113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2114", + "filePath": "resourceFile2114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2115", + "filePath": "resourceFile2115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2116", + "filePath": "resourceFile2116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2117", + "filePath": "resourceFile2117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2118", + "filePath": "resourceFile2118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2119", + "filePath": "resourceFile2119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2120", + "filePath": "resourceFile2120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2121", + "filePath": "resourceFile2121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2122", + "filePath": "resourceFile2122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2123", + "filePath": "resourceFile2123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2124", + "filePath": "resourceFile2124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2125", + "filePath": "resourceFile2125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2126", + "filePath": "resourceFile2126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2127", + "filePath": "resourceFile2127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2128", + "filePath": "resourceFile2128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2129", + "filePath": "resourceFile2129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2130", + "filePath": "resourceFile2130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2131", + "filePath": "resourceFile2131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2132", + "filePath": "resourceFile2132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2133", + "filePath": "resourceFile2133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2134", + "filePath": "resourceFile2134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2135", + "filePath": "resourceFile2135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2136", + "filePath": "resourceFile2136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2137", + "filePath": "resourceFile2137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2138", + "filePath": "resourceFile2138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2139", + "filePath": "resourceFile2139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2140", + "filePath": "resourceFile2140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2141", + "filePath": "resourceFile2141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2142", + "filePath": "resourceFile2142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2143", + "filePath": "resourceFile2143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2144", + "filePath": "resourceFile2144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2145", + "filePath": "resourceFile2145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2146", + "filePath": "resourceFile2146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2147", + "filePath": "resourceFile2147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2148", + "filePath": "resourceFile2148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2149", + "filePath": "resourceFile2149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2150", + "filePath": "resourceFile2150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2151", + "filePath": "resourceFile2151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2152", + "filePath": "resourceFile2152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2153", + "filePath": "resourceFile2153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2154", + "filePath": "resourceFile2154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2155", + "filePath": "resourceFile2155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2156", + "filePath": "resourceFile2156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2157", + "filePath": "resourceFile2157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2158", + "filePath": "resourceFile2158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2159", + "filePath": "resourceFile2159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2160", + "filePath": "resourceFile2160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2161", + "filePath": "resourceFile2161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2162", + "filePath": "resourceFile2162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2163", + "filePath": "resourceFile2163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2164", + "filePath": "resourceFile2164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2165", + "filePath": "resourceFile2165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2166", + "filePath": "resourceFile2166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2167", + "filePath": "resourceFile2167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2168", + "filePath": "resourceFile2168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2169", + "filePath": "resourceFile2169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2170", + "filePath": "resourceFile2170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2171", + "filePath": "resourceFile2171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2172", + "filePath": "resourceFile2172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2173", + "filePath": "resourceFile2173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2174", + "filePath": "resourceFile2174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2175", + "filePath": "resourceFile2175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2176", + "filePath": "resourceFile2176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2177", + "filePath": "resourceFile2177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2178", + "filePath": "resourceFile2178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2179", + "filePath": "resourceFile2179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2180", + "filePath": "resourceFile2180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2181", + "filePath": "resourceFile2181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2182", + "filePath": "resourceFile2182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2183", + "filePath": "resourceFile2183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2184", + "filePath": "resourceFile2184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2185", + "filePath": "resourceFile2185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2186", + "filePath": "resourceFile2186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2187", + "filePath": "resourceFile2187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2188", + "filePath": "resourceFile2188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2189", + "filePath": "resourceFile2189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2190", + "filePath": "resourceFile2190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2191", + "filePath": "resourceFile2191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2192", + "filePath": "resourceFile2192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2193", + "filePath": "resourceFile2193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2194", + "filePath": "resourceFile2194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2195", + "filePath": "resourceFile2195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2196", + "filePath": "resourceFile2196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2197", + "filePath": "resourceFile2197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2198", + "filePath": "resourceFile2198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2199", + "filePath": "resourceFile2199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2200", + "filePath": "resourceFile2200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2201", + "filePath": "resourceFile2201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2202", + "filePath": "resourceFile2202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2203", + "filePath": "resourceFile2203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2204", + "filePath": "resourceFile2204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2205", + "filePath": "resourceFile2205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2206", + "filePath": "resourceFile2206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2207", + "filePath": "resourceFile2207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2208", + "filePath": "resourceFile2208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2209", + "filePath": "resourceFile2209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2210", + "filePath": "resourceFile2210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2211", + "filePath": "resourceFile2211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2212", + "filePath": "resourceFile2212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2213", + "filePath": "resourceFile2213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2214", + "filePath": "resourceFile2214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2215", + "filePath": "resourceFile2215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2216", + "filePath": "resourceFile2216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2217", + "filePath": "resourceFile2217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2218", + "filePath": "resourceFile2218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2219", + "filePath": "resourceFile2219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2220", + "filePath": "resourceFile2220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2221", + "filePath": "resourceFile2221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2222", + "filePath": "resourceFile2222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2223", + "filePath": "resourceFile2223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2224", + "filePath": "resourceFile2224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2225", + "filePath": "resourceFile2225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2226", + "filePath": "resourceFile2226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2227", + "filePath": "resourceFile2227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2228", + "filePath": "resourceFile2228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2229", + "filePath": "resourceFile2229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2230", + "filePath": "resourceFile2230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2231", + "filePath": "resourceFile2231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2232", + "filePath": "resourceFile2232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2233", + "filePath": "resourceFile2233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2234", + "filePath": "resourceFile2234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2235", + "filePath": "resourceFile2235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2236", + "filePath": "resourceFile2236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2237", + "filePath": "resourceFile2237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2238", + "filePath": "resourceFile2238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2239", + "filePath": "resourceFile2239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2240", + "filePath": "resourceFile2240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2241", + "filePath": "resourceFile2241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2242", + "filePath": "resourceFile2242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2243", + "filePath": "resourceFile2243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2244", + "filePath": "resourceFile2244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2245", + "filePath": "resourceFile2245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2246", + "filePath": "resourceFile2246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2247", + "filePath": "resourceFile2247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2248", + "filePath": "resourceFile2248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2249", + "filePath": "resourceFile2249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2250", + "filePath": "resourceFile2250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2251", + "filePath": "resourceFile2251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2252", + "filePath": "resourceFile2252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2253", + "filePath": "resourceFile2253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2254", + "filePath": "resourceFile2254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2255", + "filePath": "resourceFile2255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2256", + "filePath": "resourceFile2256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2257", + "filePath": "resourceFile2257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2258", + "filePath": "resourceFile2258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2259", + "filePath": "resourceFile2259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2260", + "filePath": "resourceFile2260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2261", + "filePath": "resourceFile2261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2262", + "filePath": "resourceFile2262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2263", + "filePath": "resourceFile2263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2264", + "filePath": "resourceFile2264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2265", + "filePath": "resourceFile2265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2266", + "filePath": "resourceFile2266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2267", + "filePath": "resourceFile2267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2268", + "filePath": "resourceFile2268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2269", + "filePath": "resourceFile2269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2270", + "filePath": "resourceFile2270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2271", + "filePath": "resourceFile2271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2272", + "filePath": "resourceFile2272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2273", + "filePath": "resourceFile2273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2274", + "filePath": "resourceFile2274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2275", + "filePath": "resourceFile2275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2276", + "filePath": "resourceFile2276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2277", + "filePath": "resourceFile2277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2278", + "filePath": "resourceFile2278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2279", + "filePath": "resourceFile2279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2280", + "filePath": "resourceFile2280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2281", + "filePath": "resourceFile2281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2282", + "filePath": "resourceFile2282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2283", + "filePath": "resourceFile2283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2284", + "filePath": "resourceFile2284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2285", + "filePath": "resourceFile2285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2286", + "filePath": "resourceFile2286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2287", + "filePath": "resourceFile2287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2288", + "filePath": "resourceFile2288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2289", + "filePath": "resourceFile2289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2290", + "filePath": "resourceFile2290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2291", + "filePath": "resourceFile2291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2292", + "filePath": "resourceFile2292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2293", + "filePath": "resourceFile2293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2294", + "filePath": "resourceFile2294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2295", + "filePath": "resourceFile2295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2296", + "filePath": "resourceFile2296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2297", + "filePath": "resourceFile2297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2298", + "filePath": "resourceFile2298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2299", + "filePath": "resourceFile2299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2300", + "filePath": "resourceFile2300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2301", + "filePath": "resourceFile2301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2302", + "filePath": "resourceFile2302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2303", + "filePath": "resourceFile2303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2304", + "filePath": "resourceFile2304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2305", + "filePath": "resourceFile2305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2306", + "filePath": "resourceFile2306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2307", + "filePath": "resourceFile2307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2308", + "filePath": "resourceFile2308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2309", + "filePath": "resourceFile2309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2310", + "filePath": "resourceFile2310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2311", + "filePath": "resourceFile2311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2312", + "filePath": "resourceFile2312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2313", + "filePath": "resourceFile2313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2314", + "filePath": "resourceFile2314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2315", + "filePath": "resourceFile2315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2316", + "filePath": "resourceFile2316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2317", + "filePath": "resourceFile2317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2318", + "filePath": "resourceFile2318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2319", + "filePath": "resourceFile2319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2320", + "filePath": "resourceFile2320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2321", + "filePath": "resourceFile2321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2322", + "filePath": "resourceFile2322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2323", + "filePath": "resourceFile2323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2324", + "filePath": "resourceFile2324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2325", + "filePath": "resourceFile2325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2326", + "filePath": "resourceFile2326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2327", + "filePath": "resourceFile2327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2328", + "filePath": "resourceFile2328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2329", + "filePath": "resourceFile2329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2330", + "filePath": "resourceFile2330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2331", + "filePath": "resourceFile2331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2332", + "filePath": "resourceFile2332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2333", + "filePath": "resourceFile2333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2334", + "filePath": "resourceFile2334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2335", + "filePath": "resourceFile2335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2336", + "filePath": "resourceFile2336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2337", + "filePath": "resourceFile2337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2338", + "filePath": "resourceFile2338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2339", + "filePath": "resourceFile2339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2340", + "filePath": "resourceFile2340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2341", + "filePath": "resourceFile2341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2342", + "filePath": "resourceFile2342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2343", + "filePath": "resourceFile2343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2344", + "filePath": "resourceFile2344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2345", + "filePath": "resourceFile2345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2346", + "filePath": "resourceFile2346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2347", + "filePath": "resourceFile2347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2348", + "filePath": "resourceFile2348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2349", + "filePath": "resourceFile2349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2350", + "filePath": "resourceFile2350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2351", + "filePath": "resourceFile2351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2352", + "filePath": "resourceFile2352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2353", + "filePath": "resourceFile2353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2354", + "filePath": "resourceFile2354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2355", + "filePath": "resourceFile2355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2356", + "filePath": "resourceFile2356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2357", + "filePath": "resourceFile2357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2358", + "filePath": "resourceFile2358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2359", + "filePath": "resourceFile2359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2360", + "filePath": "resourceFile2360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2361", + "filePath": "resourceFile2361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2362", + "filePath": "resourceFile2362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2363", + "filePath": "resourceFile2363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2364", + "filePath": "resourceFile2364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2365", + "filePath": "resourceFile2365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2366", + "filePath": "resourceFile2366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2367", + "filePath": "resourceFile2367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2368", + "filePath": "resourceFile2368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2369", + "filePath": "resourceFile2369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2370", + "filePath": "resourceFile2370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2371", + "filePath": "resourceFile2371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2372", + "filePath": "resourceFile2372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2373", + "filePath": "resourceFile2373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2374", + "filePath": "resourceFile2374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2375", + "filePath": "resourceFile2375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2376", + "filePath": "resourceFile2376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2377", + "filePath": "resourceFile2377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2378", + "filePath": "resourceFile2378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2379", + "filePath": "resourceFile2379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2380", + "filePath": "resourceFile2380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2381", + "filePath": "resourceFile2381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2382", + "filePath": "resourceFile2382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2383", + "filePath": "resourceFile2383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2384", + "filePath": "resourceFile2384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2385", + "filePath": "resourceFile2385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2386", + "filePath": "resourceFile2386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2387", + "filePath": "resourceFile2387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2388", + "filePath": "resourceFile2388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2389", + "filePath": "resourceFile2389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2390", + "filePath": "resourceFile2390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2391", + "filePath": "resourceFile2391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2392", + "filePath": "resourceFile2392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2393", + "filePath": "resourceFile2393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2394", + "filePath": "resourceFile2394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2395", + "filePath": "resourceFile2395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2396", + "filePath": "resourceFile2396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2397", + "filePath": "resourceFile2397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2398", + "filePath": "resourceFile2398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2399", + "filePath": "resourceFile2399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2400", + "filePath": "resourceFile2400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2401", + "filePath": "resourceFile2401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2402", + "filePath": "resourceFile2402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2403", + "filePath": "resourceFile2403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2404", + "filePath": "resourceFile2404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2405", + "filePath": "resourceFile2405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2406", + "filePath": "resourceFile2406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2407", + "filePath": "resourceFile2407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2408", + "filePath": "resourceFile2408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2409", + "filePath": "resourceFile2409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2410", + "filePath": "resourceFile2410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2411", + "filePath": "resourceFile2411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2412", + "filePath": "resourceFile2412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2413", + "filePath": "resourceFile2413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2414", + "filePath": "resourceFile2414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2415", + "filePath": "resourceFile2415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2416", + "filePath": "resourceFile2416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2417", + "filePath": "resourceFile2417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2418", + "filePath": "resourceFile2418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2419", + "filePath": "resourceFile2419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2420", + "filePath": "resourceFile2420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2421", + "filePath": "resourceFile2421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2422", + "filePath": "resourceFile2422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2423", + "filePath": "resourceFile2423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2424", + "filePath": "resourceFile2424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2425", + "filePath": "resourceFile2425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2426", + "filePath": "resourceFile2426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2427", + "filePath": "resourceFile2427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2428", + "filePath": "resourceFile2428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2429", + "filePath": "resourceFile2429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2430", + "filePath": "resourceFile2430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2431", + "filePath": "resourceFile2431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2432", + "filePath": "resourceFile2432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2433", + "filePath": "resourceFile2433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2434", + "filePath": "resourceFile2434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2435", + "filePath": "resourceFile2435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2436", + "filePath": "resourceFile2436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2437", + "filePath": "resourceFile2437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2438", + "filePath": "resourceFile2438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2439", + "filePath": "resourceFile2439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2440", + "filePath": "resourceFile2440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2441", + "filePath": "resourceFile2441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2442", + "filePath": "resourceFile2442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2443", + "filePath": "resourceFile2443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2444", + "filePath": "resourceFile2444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2445", + "filePath": "resourceFile2445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2446", + "filePath": "resourceFile2446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2447", + "filePath": "resourceFile2447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2448", + "filePath": "resourceFile2448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2449", + "filePath": "resourceFile2449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2450", + "filePath": "resourceFile2450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2451", + "filePath": "resourceFile2451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2452", + "filePath": "resourceFile2452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2453", + "filePath": "resourceFile2453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2454", + "filePath": "resourceFile2454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2455", + "filePath": "resourceFile2455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2456", + "filePath": "resourceFile2456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2457", + "filePath": "resourceFile2457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2458", + "filePath": "resourceFile2458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2459", + "filePath": "resourceFile2459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2460", + "filePath": "resourceFile2460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2461", + "filePath": "resourceFile2461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2462", + "filePath": "resourceFile2462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2463", + "filePath": "resourceFile2463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2464", + "filePath": "resourceFile2464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2465", + "filePath": "resourceFile2465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2466", + "filePath": "resourceFile2466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2467", + "filePath": "resourceFile2467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2468", + "filePath": "resourceFile2468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2469", + "filePath": "resourceFile2469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2470", + "filePath": "resourceFile2470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2471", + "filePath": "resourceFile2471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2472", + "filePath": "resourceFile2472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2473", + "filePath": "resourceFile2473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2474", + "filePath": "resourceFile2474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2475", + "filePath": "resourceFile2475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2476", + "filePath": "resourceFile2476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2477", + "filePath": "resourceFile2477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2478", + "filePath": "resourceFile2478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2479", + "filePath": "resourceFile2479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2480", + "filePath": "resourceFile2480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2481", + "filePath": "resourceFile2481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2482", + "filePath": "resourceFile2482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2483", + "filePath": "resourceFile2483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2484", + "filePath": "resourceFile2484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2485", + "filePath": "resourceFile2485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2486", + "filePath": "resourceFile2486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2487", + "filePath": "resourceFile2487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2488", + "filePath": "resourceFile2488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2489", + "filePath": "resourceFile2489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2490", + "filePath": "resourceFile2490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2491", + "filePath": "resourceFile2491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2492", + "filePath": "resourceFile2492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2493", + "filePath": "resourceFile2493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2494", + "filePath": "resourceFile2494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2495", + "filePath": "resourceFile2495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2496", + "filePath": "resourceFile2496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2497", + "filePath": "resourceFile2497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2498", + "filePath": "resourceFile2498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2499", + "filePath": "resourceFile2499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2500", + "filePath": "resourceFile2500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2501", + "filePath": "resourceFile2501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2502", + "filePath": "resourceFile2502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2503", + "filePath": "resourceFile2503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2504", + "filePath": "resourceFile2504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2505", + "filePath": "resourceFile2505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2506", + "filePath": "resourceFile2506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2507", + "filePath": "resourceFile2507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2508", + "filePath": "resourceFile2508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2509", + "filePath": "resourceFile2509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2510", + "filePath": "resourceFile2510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2511", + "filePath": "resourceFile2511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2512", + "filePath": "resourceFile2512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2513", + "filePath": "resourceFile2513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2514", + "filePath": "resourceFile2514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2515", + "filePath": "resourceFile2515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2516", + "filePath": "resourceFile2516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2517", + "filePath": "resourceFile2517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2518", + "filePath": "resourceFile2518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2519", + "filePath": "resourceFile2519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2520", + "filePath": "resourceFile2520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2521", + "filePath": "resourceFile2521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2522", + "filePath": "resourceFile2522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2523", + "filePath": "resourceFile2523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2524", + "filePath": "resourceFile2524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2525", + "filePath": "resourceFile2525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2526", + "filePath": "resourceFile2526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2527", + "filePath": "resourceFile2527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2528", + "filePath": "resourceFile2528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2529", + "filePath": "resourceFile2529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2530", + "filePath": "resourceFile2530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2531", + "filePath": "resourceFile2531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2532", + "filePath": "resourceFile2532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2533", + "filePath": "resourceFile2533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2534", + "filePath": "resourceFile2534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2535", + "filePath": "resourceFile2535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2536", + "filePath": "resourceFile2536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2537", + "filePath": "resourceFile2537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2538", + "filePath": "resourceFile2538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2539", + "filePath": "resourceFile2539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2540", + "filePath": "resourceFile2540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2541", + "filePath": "resourceFile2541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2542", + "filePath": "resourceFile2542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2543", + "filePath": "resourceFile2543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2544", + "filePath": "resourceFile2544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2545", + "filePath": "resourceFile2545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2546", + "filePath": "resourceFile2546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2547", + "filePath": "resourceFile2547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2548", + "filePath": "resourceFile2548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2549", + "filePath": "resourceFile2549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2550", + "filePath": "resourceFile2550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2551", + "filePath": "resourceFile2551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2552", + "filePath": "resourceFile2552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2553", + "filePath": "resourceFile2553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2554", + "filePath": "resourceFile2554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2555", + "filePath": "resourceFile2555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2556", + "filePath": "resourceFile2556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2557", + "filePath": "resourceFile2557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2558", + "filePath": "resourceFile2558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2559", + "filePath": "resourceFile2559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2560", + "filePath": "resourceFile2560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2561", + "filePath": "resourceFile2561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2562", + "filePath": "resourceFile2562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2563", + "filePath": "resourceFile2563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2564", + "filePath": "resourceFile2564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2565", + "filePath": "resourceFile2565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2566", + "filePath": "resourceFile2566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2567", + "filePath": "resourceFile2567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2568", + "filePath": "resourceFile2568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2569", + "filePath": "resourceFile2569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2570", + "filePath": "resourceFile2570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2571", + "filePath": "resourceFile2571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2572", + "filePath": "resourceFile2572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2573", + "filePath": "resourceFile2573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2574", + "filePath": "resourceFile2574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2575", + "filePath": "resourceFile2575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2576", + "filePath": "resourceFile2576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2577", + "filePath": "resourceFile2577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2578", + "filePath": "resourceFile2578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2579", + "filePath": "resourceFile2579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2580", + "filePath": "resourceFile2580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2581", + "filePath": "resourceFile2581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2582", + "filePath": "resourceFile2582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2583", + "filePath": "resourceFile2583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2584", + "filePath": "resourceFile2584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2585", + "filePath": "resourceFile2585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2586", + "filePath": "resourceFile2586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2587", + "filePath": "resourceFile2587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2588", + "filePath": "resourceFile2588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2589", + "filePath": "resourceFile2589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2590", + "filePath": "resourceFile2590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2591", + "filePath": "resourceFile2591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2592", + "filePath": "resourceFile2592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2593", + "filePath": "resourceFile2593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2594", + "filePath": "resourceFile2594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2595", + "filePath": "resourceFile2595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2596", + "filePath": "resourceFile2596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2597", + "filePath": "resourceFile2597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2598", + "filePath": "resourceFile2598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2599", + "filePath": "resourceFile2599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2600", + "filePath": "resourceFile2600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2601", + "filePath": "resourceFile2601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2602", + "filePath": "resourceFile2602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2603", + "filePath": "resourceFile2603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2604", + "filePath": "resourceFile2604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2605", + "filePath": "resourceFile2605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2606", + "filePath": "resourceFile2606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2607", + "filePath": "resourceFile2607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2608", + "filePath": "resourceFile2608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2609", + "filePath": "resourceFile2609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2610", + "filePath": "resourceFile2610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2611", + "filePath": "resourceFile2611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2612", + "filePath": "resourceFile2612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2613", + "filePath": "resourceFile2613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2614", + "filePath": "resourceFile2614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2615", + "filePath": "resourceFile2615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2616", + "filePath": "resourceFile2616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2617", + "filePath": "resourceFile2617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2618", + "filePath": "resourceFile2618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2619", + "filePath": "resourceFile2619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2620", + "filePath": "resourceFile2620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2621", + "filePath": "resourceFile2621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2622", + "filePath": "resourceFile2622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2623", + "filePath": "resourceFile2623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2624", + "filePath": "resourceFile2624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2625", + "filePath": "resourceFile2625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2626", + "filePath": "resourceFile2626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2627", + "filePath": "resourceFile2627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2628", + "filePath": "resourceFile2628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2629", + "filePath": "resourceFile2629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2630", + "filePath": "resourceFile2630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2631", + "filePath": "resourceFile2631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2632", + "filePath": "resourceFile2632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2633", + "filePath": "resourceFile2633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2634", + "filePath": "resourceFile2634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2635", + "filePath": "resourceFile2635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2636", + "filePath": "resourceFile2636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2637", + "filePath": "resourceFile2637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2638", + "filePath": "resourceFile2638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2639", + "filePath": "resourceFile2639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2640", + "filePath": "resourceFile2640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2641", + "filePath": "resourceFile2641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2642", + "filePath": "resourceFile2642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2643", + "filePath": "resourceFile2643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2644", + "filePath": "resourceFile2644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2645", + "filePath": "resourceFile2645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2646", + "filePath": "resourceFile2646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2647", + "filePath": "resourceFile2647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2648", + "filePath": "resourceFile2648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2649", + "filePath": "resourceFile2649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2650", + "filePath": "resourceFile2650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2651", + "filePath": "resourceFile2651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2652", + "filePath": "resourceFile2652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2653", + "filePath": "resourceFile2653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2654", + "filePath": "resourceFile2654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2655", + "filePath": "resourceFile2655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2656", + "filePath": "resourceFile2656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2657", + "filePath": "resourceFile2657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2658", + "filePath": "resourceFile2658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2659", + "filePath": "resourceFile2659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2660", + "filePath": "resourceFile2660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2661", + "filePath": "resourceFile2661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2662", + "filePath": "resourceFile2662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2663", + "filePath": "resourceFile2663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2664", + "filePath": "resourceFile2664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2665", + "filePath": "resourceFile2665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2666", + "filePath": "resourceFile2666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2667", + "filePath": "resourceFile2667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2668", + "filePath": "resourceFile2668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2669", + "filePath": "resourceFile2669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2670", + "filePath": "resourceFile2670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2671", + "filePath": "resourceFile2671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2672", + "filePath": "resourceFile2672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2673", + "filePath": "resourceFile2673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2674", + "filePath": "resourceFile2674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2675", + "filePath": "resourceFile2675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2676", + "filePath": "resourceFile2676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2677", + "filePath": "resourceFile2677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2678", + "filePath": "resourceFile2678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2679", + "filePath": "resourceFile2679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2680", + "filePath": "resourceFile2680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2681", + "filePath": "resourceFile2681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2682", + "filePath": "resourceFile2682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2683", + "filePath": "resourceFile2683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2684", + "filePath": "resourceFile2684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2685", + "filePath": "resourceFile2685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2686", + "filePath": "resourceFile2686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2687", + "filePath": "resourceFile2687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2688", + "filePath": "resourceFile2688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2689", + "filePath": "resourceFile2689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2690", + "filePath": "resourceFile2690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2691", + "filePath": "resourceFile2691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2692", + "filePath": "resourceFile2692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2693", + "filePath": "resourceFile2693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2694", + "filePath": "resourceFile2694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2695", + "filePath": "resourceFile2695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2696", + "filePath": "resourceFile2696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2697", + "filePath": "resourceFile2697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2698", + "filePath": "resourceFile2698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2699", + "filePath": "resourceFile2699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2700", + "filePath": "resourceFile2700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2701", + "filePath": "resourceFile2701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2702", + "filePath": "resourceFile2702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2703", + "filePath": "resourceFile2703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2704", + "filePath": "resourceFile2704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2705", + "filePath": "resourceFile2705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2706", + "filePath": "resourceFile2706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2707", + "filePath": "resourceFile2707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2708", + "filePath": "resourceFile2708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2709", + "filePath": "resourceFile2709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2710", + "filePath": "resourceFile2710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2711", + "filePath": "resourceFile2711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2712", + "filePath": "resourceFile2712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2713", + "filePath": "resourceFile2713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2714", + "filePath": "resourceFile2714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2715", + "filePath": "resourceFile2715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2716", + "filePath": "resourceFile2716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2717", + "filePath": "resourceFile2717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2718", + "filePath": "resourceFile2718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2719", + "filePath": "resourceFile2719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2720", + "filePath": "resourceFile2720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2721", + "filePath": "resourceFile2721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2722", + "filePath": "resourceFile2722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2723", + "filePath": "resourceFile2723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2724", + "filePath": "resourceFile2724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2725", + "filePath": "resourceFile2725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2726", + "filePath": "resourceFile2726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2727", + "filePath": "resourceFile2727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2728", + "filePath": "resourceFile2728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2729", + "filePath": "resourceFile2729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2730", + "filePath": "resourceFile2730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2731", + "filePath": "resourceFile2731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2732", + "filePath": "resourceFile2732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2733", + "filePath": "resourceFile2733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2734", + "filePath": "resourceFile2734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2735", + "filePath": "resourceFile2735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2736", + "filePath": "resourceFile2736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2737", + "filePath": "resourceFile2737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2738", + "filePath": "resourceFile2738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2739", + "filePath": "resourceFile2739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2740", + "filePath": "resourceFile2740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2741", + "filePath": "resourceFile2741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2742", + "filePath": "resourceFile2742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2743", + "filePath": "resourceFile2743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2744", + "filePath": "resourceFile2744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2745", + "filePath": "resourceFile2745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2746", + "filePath": "resourceFile2746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2747", + "filePath": "resourceFile2747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2748", + "filePath": "resourceFile2748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2749", + "filePath": "resourceFile2749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2750", + "filePath": "resourceFile2750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2751", + "filePath": "resourceFile2751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2752", + "filePath": "resourceFile2752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2753", + "filePath": "resourceFile2753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2754", + "filePath": "resourceFile2754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2755", + "filePath": "resourceFile2755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2756", + "filePath": "resourceFile2756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2757", + "filePath": "resourceFile2757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2758", + "filePath": "resourceFile2758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2759", + "filePath": "resourceFile2759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2760", + "filePath": "resourceFile2760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2761", + "filePath": "resourceFile2761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2762", + "filePath": "resourceFile2762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2763", + "filePath": "resourceFile2763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2764", + "filePath": "resourceFile2764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2765", + "filePath": "resourceFile2765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2766", + "filePath": "resourceFile2766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2767", + "filePath": "resourceFile2767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2768", + "filePath": "resourceFile2768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2769", + "filePath": "resourceFile2769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2770", + "filePath": "resourceFile2770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2771", + "filePath": "resourceFile2771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2772", + "filePath": "resourceFile2772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2773", + "filePath": "resourceFile2773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2774", + "filePath": "resourceFile2774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2775", + "filePath": "resourceFile2775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2776", + "filePath": "resourceFile2776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2777", + "filePath": "resourceFile2777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2778", + "filePath": "resourceFile2778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2779", + "filePath": "resourceFile2779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2780", + "filePath": "resourceFile2780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2781", + "filePath": "resourceFile2781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2782", + "filePath": "resourceFile2782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2783", + "filePath": "resourceFile2783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2784", + "filePath": "resourceFile2784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2785", + "filePath": "resourceFile2785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2786", + "filePath": "resourceFile2786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2787", + "filePath": "resourceFile2787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2788", + "filePath": "resourceFile2788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2789", + "filePath": "resourceFile2789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2790", + "filePath": "resourceFile2790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2791", + "filePath": "resourceFile2791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2792", + "filePath": "resourceFile2792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2793", + "filePath": "resourceFile2793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2794", + "filePath": "resourceFile2794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2795", + "filePath": "resourceFile2795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2796", + "filePath": "resourceFile2796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2797", + "filePath": "resourceFile2797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2798", + "filePath": "resourceFile2798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2799", + "filePath": "resourceFile2799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2800", + "filePath": "resourceFile2800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2801", + "filePath": "resourceFile2801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2802", + "filePath": "resourceFile2802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2803", + "filePath": "resourceFile2803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2804", + "filePath": "resourceFile2804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2805", + "filePath": "resourceFile2805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2806", + "filePath": "resourceFile2806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2807", + "filePath": "resourceFile2807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2808", + "filePath": "resourceFile2808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2809", + "filePath": "resourceFile2809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2810", + "filePath": "resourceFile2810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2811", + "filePath": "resourceFile2811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2812", + "filePath": "resourceFile2812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2813", + "filePath": "resourceFile2813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2814", + "filePath": "resourceFile2814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2815", + "filePath": "resourceFile2815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2816", + "filePath": "resourceFile2816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2817", + "filePath": "resourceFile2817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2818", + "filePath": "resourceFile2818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2819", + "filePath": "resourceFile2819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2820", + "filePath": "resourceFile2820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2821", + "filePath": "resourceFile2821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2822", + "filePath": "resourceFile2822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2823", + "filePath": "resourceFile2823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2824", + "filePath": "resourceFile2824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2825", + "filePath": "resourceFile2825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2826", + "filePath": "resourceFile2826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2827", + "filePath": "resourceFile2827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2828", + "filePath": "resourceFile2828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2829", + "filePath": "resourceFile2829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2830", + "filePath": "resourceFile2830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2831", + "filePath": "resourceFile2831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2832", + "filePath": "resourceFile2832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2833", + "filePath": "resourceFile2833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2834", + "filePath": "resourceFile2834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2835", + "filePath": "resourceFile2835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2836", + "filePath": "resourceFile2836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2837", + "filePath": "resourceFile2837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2838", + "filePath": "resourceFile2838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2839", + "filePath": "resourceFile2839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2840", + "filePath": "resourceFile2840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2841", + "filePath": "resourceFile2841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2842", + "filePath": "resourceFile2842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2843", + "filePath": "resourceFile2843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2844", + "filePath": "resourceFile2844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2845", + "filePath": "resourceFile2845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2846", + "filePath": "resourceFile2846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2847", + "filePath": "resourceFile2847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2848", + "filePath": "resourceFile2848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2849", + "filePath": "resourceFile2849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2850", + "filePath": "resourceFile2850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2851", + "filePath": "resourceFile2851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2852", + "filePath": "resourceFile2852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2853", + "filePath": "resourceFile2853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2854", + "filePath": "resourceFile2854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2855", + "filePath": "resourceFile2855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2856", + "filePath": "resourceFile2856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2857", + "filePath": "resourceFile2857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2858", + "filePath": "resourceFile2858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2859", + "filePath": "resourceFile2859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2860", + "filePath": "resourceFile2860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2861", + "filePath": "resourceFile2861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2862", + "filePath": "resourceFile2862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2863", + "filePath": "resourceFile2863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2864", + "filePath": "resourceFile2864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2865", + "filePath": "resourceFile2865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2866", + "filePath": "resourceFile2866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2867", + "filePath": "resourceFile2867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2868", + "filePath": "resourceFile2868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2869", + "filePath": "resourceFile2869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2870", + "filePath": "resourceFile2870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2871", + "filePath": "resourceFile2871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2872", + "filePath": "resourceFile2872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2873", + "filePath": "resourceFile2873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2874", + "filePath": "resourceFile2874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2875", + "filePath": "resourceFile2875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2876", + "filePath": "resourceFile2876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2877", + "filePath": "resourceFile2877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2878", + "filePath": "resourceFile2878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2879", + "filePath": "resourceFile2879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2880", + "filePath": "resourceFile2880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2881", + "filePath": "resourceFile2881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2882", + "filePath": "resourceFile2882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2883", + "filePath": "resourceFile2883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2884", + "filePath": "resourceFile2884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2885", + "filePath": "resourceFile2885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2886", + "filePath": "resourceFile2886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2887", + "filePath": "resourceFile2887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2888", + "filePath": "resourceFile2888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2889", + "filePath": "resourceFile2889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2890", + "filePath": "resourceFile2890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2891", + "filePath": "resourceFile2891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2892", + "filePath": "resourceFile2892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2893", + "filePath": "resourceFile2893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2894", + "filePath": "resourceFile2894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2895", + "filePath": "resourceFile2895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2896", + "filePath": "resourceFile2896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2897", + "filePath": "resourceFile2897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2898", + "filePath": "resourceFile2898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2899", + "filePath": "resourceFile2899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2900", + "filePath": "resourceFile2900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2901", + "filePath": "resourceFile2901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2902", + "filePath": "resourceFile2902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2903", + "filePath": "resourceFile2903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2904", + "filePath": "resourceFile2904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2905", + "filePath": "resourceFile2905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2906", + "filePath": "resourceFile2906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2907", + "filePath": "resourceFile2907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2908", + "filePath": "resourceFile2908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2909", + "filePath": "resourceFile2909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2910", + "filePath": "resourceFile2910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2911", + "filePath": "resourceFile2911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2912", + "filePath": "resourceFile2912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2913", + "filePath": "resourceFile2913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2914", + "filePath": "resourceFile2914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2915", + "filePath": "resourceFile2915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2916", + "filePath": "resourceFile2916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2917", + "filePath": "resourceFile2917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2918", + "filePath": "resourceFile2918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2919", + "filePath": "resourceFile2919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2920", + "filePath": "resourceFile2920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2921", + "filePath": "resourceFile2921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2922", + "filePath": "resourceFile2922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2923", + "filePath": "resourceFile2923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2924", + "filePath": "resourceFile2924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2925", + "filePath": "resourceFile2925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2926", + "filePath": "resourceFile2926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2927", + "filePath": "resourceFile2927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2928", + "filePath": "resourceFile2928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2929", + "filePath": "resourceFile2929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2930", + "filePath": "resourceFile2930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2931", + "filePath": "resourceFile2931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2932", + "filePath": "resourceFile2932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2933", + "filePath": "resourceFile2933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2934", + "filePath": "resourceFile2934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2935", + "filePath": "resourceFile2935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2936", + "filePath": "resourceFile2936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2937", + "filePath": "resourceFile2937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2938", + "filePath": "resourceFile2938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2939", + "filePath": "resourceFile2939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2940", + "filePath": "resourceFile2940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2941", + "filePath": "resourceFile2941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2942", + "filePath": "resourceFile2942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2943", + "filePath": "resourceFile2943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2944", + "filePath": "resourceFile2944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2945", + "filePath": "resourceFile2945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2946", + "filePath": "resourceFile2946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2947", + "filePath": "resourceFile2947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2948", + "filePath": "resourceFile2948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2949", + "filePath": "resourceFile2949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2950", + "filePath": "resourceFile2950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2951", + "filePath": "resourceFile2951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2952", + "filePath": "resourceFile2952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2953", + "filePath": "resourceFile2953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2954", + "filePath": "resourceFile2954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2955", + "filePath": "resourceFile2955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2956", + "filePath": "resourceFile2956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2957", + "filePath": "resourceFile2957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2958", + "filePath": "resourceFile2958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2959", + "filePath": "resourceFile2959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2960", + "filePath": "resourceFile2960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2961", + "filePath": "resourceFile2961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2962", + "filePath": "resourceFile2962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2963", + "filePath": "resourceFile2963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2964", + "filePath": "resourceFile2964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2965", + "filePath": "resourceFile2965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2966", + "filePath": "resourceFile2966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2967", + "filePath": "resourceFile2967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2968", + "filePath": "resourceFile2968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2969", + "filePath": "resourceFile2969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2970", + "filePath": "resourceFile2970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2971", + "filePath": "resourceFile2971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2972", + "filePath": "resourceFile2972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2973", + "filePath": "resourceFile2973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2974", + "filePath": "resourceFile2974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2975", + "filePath": "resourceFile2975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2976", + "filePath": "resourceFile2976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2977", + "filePath": "resourceFile2977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2978", + "filePath": "resourceFile2978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2979", + "filePath": "resourceFile2979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2980", + "filePath": "resourceFile2980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2981", + "filePath": "resourceFile2981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2982", + "filePath": "resourceFile2982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2983", + "filePath": "resourceFile2983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2984", + "filePath": "resourceFile2984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2985", + "filePath": "resourceFile2985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2986", + "filePath": "resourceFile2986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2987", + "filePath": "resourceFile2987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2988", + "filePath": "resourceFile2988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2989", + "filePath": "resourceFile2989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2990", + "filePath": "resourceFile2990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2991", + "filePath": "resourceFile2991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2992", + "filePath": "resourceFile2992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2993", + "filePath": "resourceFile2993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2994", + "filePath": "resourceFile2994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2995", + "filePath": "resourceFile2995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2996", + "filePath": "resourceFile2996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2997", + "filePath": "resourceFile2997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2998", + "filePath": "resourceFile2998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2999", + "filePath": "resourceFile2999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3000", + "filePath": "resourceFile3000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3001", + "filePath": "resourceFile3001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3002", + "filePath": "resourceFile3002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3003", + "filePath": "resourceFile3003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3004", + "filePath": "resourceFile3004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3005", + "filePath": "resourceFile3005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3006", + "filePath": "resourceFile3006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3007", + "filePath": "resourceFile3007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3008", + "filePath": "resourceFile3008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3009", + "filePath": "resourceFile3009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3010", + "filePath": "resourceFile3010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3011", + "filePath": "resourceFile3011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3012", + "filePath": "resourceFile3012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3013", + "filePath": "resourceFile3013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3014", + "filePath": "resourceFile3014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3015", + "filePath": "resourceFile3015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3016", + "filePath": "resourceFile3016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3017", + "filePath": "resourceFile3017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3018", + "filePath": "resourceFile3018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3019", + "filePath": "resourceFile3019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3020", + "filePath": "resourceFile3020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3021", + "filePath": "resourceFile3021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3022", + "filePath": "resourceFile3022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3023", + "filePath": "resourceFile3023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3024", + "filePath": "resourceFile3024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3025", + "filePath": "resourceFile3025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3026", + "filePath": "resourceFile3026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3027", + "filePath": "resourceFile3027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3028", + "filePath": "resourceFile3028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3029", + "filePath": "resourceFile3029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3030", + "filePath": "resourceFile3030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3031", + "filePath": "resourceFile3031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3032", + "filePath": "resourceFile3032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3033", + "filePath": "resourceFile3033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3034", + "filePath": "resourceFile3034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3035", + "filePath": "resourceFile3035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3036", + "filePath": "resourceFile3036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3037", + "filePath": "resourceFile3037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3038", + "filePath": "resourceFile3038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3039", + "filePath": "resourceFile3039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3040", + "filePath": "resourceFile3040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3041", + "filePath": "resourceFile3041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3042", + "filePath": "resourceFile3042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3043", + "filePath": "resourceFile3043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3044", + "filePath": "resourceFile3044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3045", + "filePath": "resourceFile3045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3046", + "filePath": "resourceFile3046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3047", + "filePath": "resourceFile3047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3048", + "filePath": "resourceFile3048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3049", + "filePath": "resourceFile3049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3050", + "filePath": "resourceFile3050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3051", + "filePath": "resourceFile3051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3052", + "filePath": "resourceFile3052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3053", + "filePath": "resourceFile3053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3054", + "filePath": "resourceFile3054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3055", + "filePath": "resourceFile3055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3056", + "filePath": "resourceFile3056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3057", + "filePath": "resourceFile3057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3058", + "filePath": "resourceFile3058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3059", + "filePath": "resourceFile3059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3060", + "filePath": "resourceFile3060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3061", + "filePath": "resourceFile3061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3062", + "filePath": "resourceFile3062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3063", + "filePath": "resourceFile3063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3064", + "filePath": "resourceFile3064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3065", + "filePath": "resourceFile3065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3066", + "filePath": "resourceFile3066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3067", + "filePath": "resourceFile3067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3068", + "filePath": "resourceFile3068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3069", + "filePath": "resourceFile3069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3070", + "filePath": "resourceFile3070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3071", + "filePath": "resourceFile3071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3072", + "filePath": "resourceFile3072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3073", + "filePath": "resourceFile3073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3074", + "filePath": "resourceFile3074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3075", + "filePath": "resourceFile3075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3076", + "filePath": "resourceFile3076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3077", + "filePath": "resourceFile3077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3078", + "filePath": "resourceFile3078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3079", + "filePath": "resourceFile3079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3080", + "filePath": "resourceFile3080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3081", + "filePath": "resourceFile3081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3082", + "filePath": "resourceFile3082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3083", + "filePath": "resourceFile3083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3084", + "filePath": "resourceFile3084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3085", + "filePath": "resourceFile3085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3086", + "filePath": "resourceFile3086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3087", + "filePath": "resourceFile3087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3088", + "filePath": "resourceFile3088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3089", + "filePath": "resourceFile3089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3090", + "filePath": "resourceFile3090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3091", + "filePath": "resourceFile3091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3092", + "filePath": "resourceFile3092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3093", + "filePath": "resourceFile3093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3094", + "filePath": "resourceFile3094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3095", + "filePath": "resourceFile3095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3096", + "filePath": "resourceFile3096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3097", + "filePath": "resourceFile3097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3098", + "filePath": "resourceFile3098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3099", + "filePath": "resourceFile3099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3100", + "filePath": "resourceFile3100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3101", + "filePath": "resourceFile3101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3102", + "filePath": "resourceFile3102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3103", + "filePath": "resourceFile3103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3104", + "filePath": "resourceFile3104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3105", + "filePath": "resourceFile3105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3106", + "filePath": "resourceFile3106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3107", + "filePath": "resourceFile3107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3108", + "filePath": "resourceFile3108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3109", + "filePath": "resourceFile3109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3110", + "filePath": "resourceFile3110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3111", + "filePath": "resourceFile3111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3112", + "filePath": "resourceFile3112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3113", + "filePath": "resourceFile3113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3114", + "filePath": "resourceFile3114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3115", + "filePath": "resourceFile3115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3116", + "filePath": "resourceFile3116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3117", + "filePath": "resourceFile3117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3118", + "filePath": "resourceFile3118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3119", + "filePath": "resourceFile3119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3120", + "filePath": "resourceFile3120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3121", + "filePath": "resourceFile3121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3122", + "filePath": "resourceFile3122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3123", + "filePath": "resourceFile3123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3124", + "filePath": "resourceFile3124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3125", + "filePath": "resourceFile3125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3126", + "filePath": "resourceFile3126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3127", + "filePath": "resourceFile3127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3128", + "filePath": "resourceFile3128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3129", + "filePath": "resourceFile3129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3130", + "filePath": "resourceFile3130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3131", + "filePath": "resourceFile3131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3132", + "filePath": "resourceFile3132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3133", + "filePath": "resourceFile3133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3134", + "filePath": "resourceFile3134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3135", + "filePath": "resourceFile3135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3136", + "filePath": "resourceFile3136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3137", + "filePath": "resourceFile3137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3138", + "filePath": "resourceFile3138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3139", + "filePath": "resourceFile3139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3140", + "filePath": "resourceFile3140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3141", + "filePath": "resourceFile3141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3142", + "filePath": "resourceFile3142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3143", + "filePath": "resourceFile3143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3144", + "filePath": "resourceFile3144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3145", + "filePath": "resourceFile3145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3146", + "filePath": "resourceFile3146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3147", + "filePath": "resourceFile3147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3148", + "filePath": "resourceFile3148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3149", + "filePath": "resourceFile3149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3150", + "filePath": "resourceFile3150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3151", + "filePath": "resourceFile3151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3152", + "filePath": "resourceFile3152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3153", + "filePath": "resourceFile3153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3154", + "filePath": "resourceFile3154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3155", + "filePath": "resourceFile3155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3156", + "filePath": "resourceFile3156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3157", + "filePath": "resourceFile3157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3158", + "filePath": "resourceFile3158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3159", + "filePath": "resourceFile3159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3160", + "filePath": "resourceFile3160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3161", + "filePath": "resourceFile3161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3162", + "filePath": "resourceFile3162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3163", + "filePath": "resourceFile3163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3164", + "filePath": "resourceFile3164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3165", + "filePath": "resourceFile3165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3166", + "filePath": "resourceFile3166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3167", + "filePath": "resourceFile3167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3168", + "filePath": "resourceFile3168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3169", + "filePath": "resourceFile3169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3170", + "filePath": "resourceFile3170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3171", + "filePath": "resourceFile3171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3172", + "filePath": "resourceFile3172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3173", + "filePath": "resourceFile3173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3174", + "filePath": "resourceFile3174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3175", + "filePath": "resourceFile3175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3176", + "filePath": "resourceFile3176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3177", + "filePath": "resourceFile3177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3178", + "filePath": "resourceFile3178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3179", + "filePath": "resourceFile3179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3180", + "filePath": "resourceFile3180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3181", + "filePath": "resourceFile3181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3182", + "filePath": "resourceFile3182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3183", + "filePath": "resourceFile3183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3184", + "filePath": "resourceFile3184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3185", + "filePath": "resourceFile3185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3186", + "filePath": "resourceFile3186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3187", + "filePath": "resourceFile3187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3188", + "filePath": "resourceFile3188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3189", + "filePath": "resourceFile3189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3190", + "filePath": "resourceFile3190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3191", + "filePath": "resourceFile3191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3192", + "filePath": "resourceFile3192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3193", + "filePath": "resourceFile3193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3194", + "filePath": "resourceFile3194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3195", + "filePath": "resourceFile3195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3196", + "filePath": "resourceFile3196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3197", + "filePath": "resourceFile3197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3198", + "filePath": "resourceFile3198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3199", + "filePath": "resourceFile3199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3200", + "filePath": "resourceFile3200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3201", + "filePath": "resourceFile3201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3202", + "filePath": "resourceFile3202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3203", + "filePath": "resourceFile3203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3204", + "filePath": "resourceFile3204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3205", + "filePath": "resourceFile3205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3206", + "filePath": "resourceFile3206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3207", + "filePath": "resourceFile3207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3208", + "filePath": "resourceFile3208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3209", + "filePath": "resourceFile3209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3210", + "filePath": "resourceFile3210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3211", + "filePath": "resourceFile3211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3212", + "filePath": "resourceFile3212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3213", + "filePath": "resourceFile3213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3214", + "filePath": "resourceFile3214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3215", + "filePath": "resourceFile3215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3216", + "filePath": "resourceFile3216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3217", + "filePath": "resourceFile3217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3218", + "filePath": "resourceFile3218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3219", + "filePath": "resourceFile3219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3220", + "filePath": "resourceFile3220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3221", + "filePath": "resourceFile3221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3222", + "filePath": "resourceFile3222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3223", + "filePath": "resourceFile3223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3224", + "filePath": "resourceFile3224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3225", + "filePath": "resourceFile3225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3226", + "filePath": "resourceFile3226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3227", + "filePath": "resourceFile3227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3228", + "filePath": "resourceFile3228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3229", + "filePath": "resourceFile3229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3230", + "filePath": "resourceFile3230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3231", + "filePath": "resourceFile3231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3232", + "filePath": "resourceFile3232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3233", + "filePath": "resourceFile3233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3234", + "filePath": "resourceFile3234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3235", + "filePath": "resourceFile3235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3236", + "filePath": "resourceFile3236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3237", + "filePath": "resourceFile3237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3238", + "filePath": "resourceFile3238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3239", + "filePath": "resourceFile3239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3240", + "filePath": "resourceFile3240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3241", + "filePath": "resourceFile3241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3242", + "filePath": "resourceFile3242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3243", + "filePath": "resourceFile3243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3244", + "filePath": "resourceFile3244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3245", + "filePath": "resourceFile3245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3246", + "filePath": "resourceFile3246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3247", + "filePath": "resourceFile3247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3248", + "filePath": "resourceFile3248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3249", + "filePath": "resourceFile3249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3250", + "filePath": "resourceFile3250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3251", + "filePath": "resourceFile3251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3252", + "filePath": "resourceFile3252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3253", + "filePath": "resourceFile3253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3254", + "filePath": "resourceFile3254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3255", + "filePath": "resourceFile3255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3256", + "filePath": "resourceFile3256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3257", + "filePath": "resourceFile3257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3258", + "filePath": "resourceFile3258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3259", + "filePath": "resourceFile3259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3260", + "filePath": "resourceFile3260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3261", + "filePath": "resourceFile3261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3262", + "filePath": "resourceFile3262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3263", + "filePath": "resourceFile3263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3264", + "filePath": "resourceFile3264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3265", + "filePath": "resourceFile3265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3266", + "filePath": "resourceFile3266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3267", + "filePath": "resourceFile3267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3268", + "filePath": "resourceFile3268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3269", + "filePath": "resourceFile3269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3270", + "filePath": "resourceFile3270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3271", + "filePath": "resourceFile3271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3272", + "filePath": "resourceFile3272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3273", + "filePath": "resourceFile3273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3274", + "filePath": "resourceFile3274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3275", + "filePath": "resourceFile3275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3276", + "filePath": "resourceFile3276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3277", + "filePath": "resourceFile3277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3278", + "filePath": "resourceFile3278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3279", + "filePath": "resourceFile3279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3280", + "filePath": "resourceFile3280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3281", + "filePath": "resourceFile3281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3282", + "filePath": "resourceFile3282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3283", + "filePath": "resourceFile3283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3284", + "filePath": "resourceFile3284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3285", + "filePath": "resourceFile3285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3286", + "filePath": "resourceFile3286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3287", + "filePath": "resourceFile3287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3288", + "filePath": "resourceFile3288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3289", + "filePath": "resourceFile3289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3290", + "filePath": "resourceFile3290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3291", + "filePath": "resourceFile3291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3292", + "filePath": "resourceFile3292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3293", + "filePath": "resourceFile3293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3294", + "filePath": "resourceFile3294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3295", + "filePath": "resourceFile3295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3296", + "filePath": "resourceFile3296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3297", + "filePath": "resourceFile3297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3298", + "filePath": "resourceFile3298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3299", + "filePath": "resourceFile3299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3300", + "filePath": "resourceFile3300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3301", + "filePath": "resourceFile3301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3302", + "filePath": "resourceFile3302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3303", + "filePath": "resourceFile3303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3304", + "filePath": "resourceFile3304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3305", + "filePath": "resourceFile3305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3306", + "filePath": "resourceFile3306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3307", + "filePath": "resourceFile3307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3308", + "filePath": "resourceFile3308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3309", + "filePath": "resourceFile3309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3310", + "filePath": "resourceFile3310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3311", + "filePath": "resourceFile3311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3312", + "filePath": "resourceFile3312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3313", + "filePath": "resourceFile3313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3314", + "filePath": "resourceFile3314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3315", + "filePath": "resourceFile3315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3316", + "filePath": "resourceFile3316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3317", + "filePath": "resourceFile3317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3318", + "filePath": "resourceFile3318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3319", + "filePath": "resourceFile3319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3320", + "filePath": "resourceFile3320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3321", + "filePath": "resourceFile3321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3322", + "filePath": "resourceFile3322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3323", + "filePath": "resourceFile3323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3324", + "filePath": "resourceFile3324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3325", + "filePath": "resourceFile3325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3326", + "filePath": "resourceFile3326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3327", + "filePath": "resourceFile3327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3328", + "filePath": "resourceFile3328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3329", + "filePath": "resourceFile3329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3330", + "filePath": "resourceFile3330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3331", + "filePath": "resourceFile3331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3332", + "filePath": "resourceFile3332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3333", + "filePath": "resourceFile3333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3334", + "filePath": "resourceFile3334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3335", + "filePath": "resourceFile3335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3336", + "filePath": "resourceFile3336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3337", + "filePath": "resourceFile3337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3338", + "filePath": "resourceFile3338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3339", + "filePath": "resourceFile3339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3340", + "filePath": "resourceFile3340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3341", + "filePath": "resourceFile3341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3342", + "filePath": "resourceFile3342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3343", + "filePath": "resourceFile3343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3344", + "filePath": "resourceFile3344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3345", + "filePath": "resourceFile3345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3346", + "filePath": "resourceFile3346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3347", + "filePath": "resourceFile3347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3348", + "filePath": "resourceFile3348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3349", + "filePath": "resourceFile3349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3350", + "filePath": "resourceFile3350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3351", + "filePath": "resourceFile3351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3352", + "filePath": "resourceFile3352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3353", + "filePath": "resourceFile3353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3354", + "filePath": "resourceFile3354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3355", + "filePath": "resourceFile3355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3356", + "filePath": "resourceFile3356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3357", + "filePath": "resourceFile3357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3358", + "filePath": "resourceFile3358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3359", + "filePath": "resourceFile3359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3360", + "filePath": "resourceFile3360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3361", + "filePath": "resourceFile3361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3362", + "filePath": "resourceFile3362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3363", + "filePath": "resourceFile3363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3364", + "filePath": "resourceFile3364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3365", + "filePath": "resourceFile3365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3366", + "filePath": "resourceFile3366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3367", + "filePath": "resourceFile3367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3368", + "filePath": "resourceFile3368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3369", + "filePath": "resourceFile3369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3370", + "filePath": "resourceFile3370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3371", + "filePath": "resourceFile3371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3372", + "filePath": "resourceFile3372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3373", + "filePath": "resourceFile3373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3374", + "filePath": "resourceFile3374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3375", + "filePath": "resourceFile3375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3376", + "filePath": "resourceFile3376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3377", + "filePath": "resourceFile3377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3378", + "filePath": "resourceFile3378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3379", + "filePath": "resourceFile3379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3380", + "filePath": "resourceFile3380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3381", + "filePath": "resourceFile3381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3382", + "filePath": "resourceFile3382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3383", + "filePath": "resourceFile3383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3384", + "filePath": "resourceFile3384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3385", + "filePath": "resourceFile3385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3386", + "filePath": "resourceFile3386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3387", + "filePath": "resourceFile3387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3388", + "filePath": "resourceFile3388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3389", + "filePath": "resourceFile3389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3390", + "filePath": "resourceFile3390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3391", + "filePath": "resourceFile3391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3392", + "filePath": "resourceFile3392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3393", + "filePath": "resourceFile3393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3394", + "filePath": "resourceFile3394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3395", + "filePath": "resourceFile3395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3396", + "filePath": "resourceFile3396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3397", + "filePath": "resourceFile3397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3398", + "filePath": "resourceFile3398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3399", + "filePath": "resourceFile3399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3400", + "filePath": "resourceFile3400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3401", + "filePath": "resourceFile3401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3402", + "filePath": "resourceFile3402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3403", + "filePath": "resourceFile3403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3404", + "filePath": "resourceFile3404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3405", + "filePath": "resourceFile3405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3406", + "filePath": "resourceFile3406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3407", + "filePath": "resourceFile3407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3408", + "filePath": "resourceFile3408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3409", + "filePath": "resourceFile3409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3410", + "filePath": "resourceFile3410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3411", + "filePath": "resourceFile3411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3412", + "filePath": "resourceFile3412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3413", + "filePath": "resourceFile3413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3414", + "filePath": "resourceFile3414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3415", + "filePath": "resourceFile3415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3416", + "filePath": "resourceFile3416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3417", + "filePath": "resourceFile3417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3418", + "filePath": "resourceFile3418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3419", + "filePath": "resourceFile3419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3420", + "filePath": "resourceFile3420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3421", + "filePath": "resourceFile3421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3422", + "filePath": "resourceFile3422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3423", + "filePath": "resourceFile3423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3424", + "filePath": "resourceFile3424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3425", + "filePath": "resourceFile3425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3426", + "filePath": "resourceFile3426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3427", + "filePath": "resourceFile3427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3428", + "filePath": "resourceFile3428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3429", + "filePath": "resourceFile3429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3430", + "filePath": "resourceFile3430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3431", + "filePath": "resourceFile3431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3432", + "filePath": "resourceFile3432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3433", + "filePath": "resourceFile3433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3434", + "filePath": "resourceFile3434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3435", + "filePath": "resourceFile3435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3436", + "filePath": "resourceFile3436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3437", + "filePath": "resourceFile3437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3438", + "filePath": "resourceFile3438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3439", + "filePath": "resourceFile3439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3440", + "filePath": "resourceFile3440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3441", + "filePath": "resourceFile3441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3442", + "filePath": "resourceFile3442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3443", + "filePath": "resourceFile3443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3444", + "filePath": "resourceFile3444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3445", + "filePath": "resourceFile3445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3446", + "filePath": "resourceFile3446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3447", + "filePath": "resourceFile3447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3448", + "filePath": "resourceFile3448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3449", + "filePath": "resourceFile3449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3450", + "filePath": "resourceFile3450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3451", + "filePath": "resourceFile3451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3452", + "filePath": "resourceFile3452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3453", + "filePath": "resourceFile3453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3454", + "filePath": "resourceFile3454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3455", + "filePath": "resourceFile3455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3456", + "filePath": "resourceFile3456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3457", + "filePath": "resourceFile3457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3458", + "filePath": "resourceFile3458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3459", + "filePath": "resourceFile3459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3460", + "filePath": "resourceFile3460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3461", + "filePath": "resourceFile3461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3462", + "filePath": "resourceFile3462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3463", + "filePath": "resourceFile3463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3464", + "filePath": "resourceFile3464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3465", + "filePath": "resourceFile3465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3466", + "filePath": "resourceFile3466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3467", + "filePath": "resourceFile3467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3468", + "filePath": "resourceFile3468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3469", + "filePath": "resourceFile3469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3470", + "filePath": "resourceFile3470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3471", + "filePath": "resourceFile3471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3472", + "filePath": "resourceFile3472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3473", + "filePath": "resourceFile3473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3474", + "filePath": "resourceFile3474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3475", + "filePath": "resourceFile3475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3476", + "filePath": "resourceFile3476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3477", + "filePath": "resourceFile3477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3478", + "filePath": "resourceFile3478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3479", + "filePath": "resourceFile3479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3480", + "filePath": "resourceFile3480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3481", + "filePath": "resourceFile3481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3482", + "filePath": "resourceFile3482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3483", + "filePath": "resourceFile3483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3484", + "filePath": "resourceFile3484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3485", + "filePath": "resourceFile3485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3486", + "filePath": "resourceFile3486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3487", + "filePath": "resourceFile3487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3488", + "filePath": "resourceFile3488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3489", + "filePath": "resourceFile3489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3490", + "filePath": "resourceFile3490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3491", + "filePath": "resourceFile3491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3492", + "filePath": "resourceFile3492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3493", + "filePath": "resourceFile3493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3494", + "filePath": "resourceFile3494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3495", + "filePath": "resourceFile3495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3496", + "filePath": "resourceFile3496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3497", + "filePath": "resourceFile3497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3498", + "filePath": "resourceFile3498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3499", + "filePath": "resourceFile3499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3500", + "filePath": "resourceFile3500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3501", + "filePath": "resourceFile3501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3502", + "filePath": "resourceFile3502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3503", + "filePath": "resourceFile3503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3504", + "filePath": "resourceFile3504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3505", + "filePath": "resourceFile3505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3506", + "filePath": "resourceFile3506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3507", + "filePath": "resourceFile3507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3508", + "filePath": "resourceFile3508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3509", + "filePath": "resourceFile3509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3510", + "filePath": "resourceFile3510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3511", + "filePath": "resourceFile3511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3512", + "filePath": "resourceFile3512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3513", + "filePath": "resourceFile3513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3514", + "filePath": "resourceFile3514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3515", + "filePath": "resourceFile3515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3516", + "filePath": "resourceFile3516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3517", + "filePath": "resourceFile3517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3518", + "filePath": "resourceFile3518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3519", + "filePath": "resourceFile3519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3520", + "filePath": "resourceFile3520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3521", + "filePath": "resourceFile3521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3522", + "filePath": "resourceFile3522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3523", + "filePath": "resourceFile3523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3524", + "filePath": "resourceFile3524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3525", + "filePath": "resourceFile3525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3526", + "filePath": "resourceFile3526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3527", + "filePath": "resourceFile3527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3528", + "filePath": "resourceFile3528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3529", + "filePath": "resourceFile3529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3530", + "filePath": "resourceFile3530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3531", + "filePath": "resourceFile3531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3532", + "filePath": "resourceFile3532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3533", + "filePath": "resourceFile3533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3534", + "filePath": "resourceFile3534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3535", + "filePath": "resourceFile3535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3536", + "filePath": "resourceFile3536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3537", + "filePath": "resourceFile3537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3538", + "filePath": "resourceFile3538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3539", + "filePath": "resourceFile3539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3540", + "filePath": "resourceFile3540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3541", + "filePath": "resourceFile3541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3542", + "filePath": "resourceFile3542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3543", + "filePath": "resourceFile3543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3544", + "filePath": "resourceFile3544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3545", + "filePath": "resourceFile3545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3546", + "filePath": "resourceFile3546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3547", + "filePath": "resourceFile3547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3548", + "filePath": "resourceFile3548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3549", + "filePath": "resourceFile3549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3550", + "filePath": "resourceFile3550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3551", + "filePath": "resourceFile3551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3552", + "filePath": "resourceFile3552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3553", + "filePath": "resourceFile3553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3554", + "filePath": "resourceFile3554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3555", + "filePath": "resourceFile3555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3556", + "filePath": "resourceFile3556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3557", + "filePath": "resourceFile3557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3558", + "filePath": "resourceFile3558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3559", + "filePath": "resourceFile3559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3560", + "filePath": "resourceFile3560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3561", + "filePath": "resourceFile3561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3562", + "filePath": "resourceFile3562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3563", + "filePath": "resourceFile3563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3564", + "filePath": "resourceFile3564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3565", + "filePath": "resourceFile3565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3566", + "filePath": "resourceFile3566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3567", + "filePath": "resourceFile3567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3568", + "filePath": "resourceFile3568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3569", + "filePath": "resourceFile3569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3570", + "filePath": "resourceFile3570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3571", + "filePath": "resourceFile3571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3572", + "filePath": "resourceFile3572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3573", + "filePath": "resourceFile3573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3574", + "filePath": "resourceFile3574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3575", + "filePath": "resourceFile3575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3576", + "filePath": "resourceFile3576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3577", + "filePath": "resourceFile3577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3578", + "filePath": "resourceFile3578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3579", + "filePath": "resourceFile3579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3580", + "filePath": "resourceFile3580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3581", + "filePath": "resourceFile3581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3582", + "filePath": "resourceFile3582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3583", + "filePath": "resourceFile3583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3584", + "filePath": "resourceFile3584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3585", + "filePath": "resourceFile3585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3586", + "filePath": "resourceFile3586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3587", + "filePath": "resourceFile3587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3588", + "filePath": "resourceFile3588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3589", + "filePath": "resourceFile3589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3590", + "filePath": "resourceFile3590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3591", + "filePath": "resourceFile3591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3592", + "filePath": "resourceFile3592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3593", + "filePath": "resourceFile3593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3594", + "filePath": "resourceFile3594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3595", + "filePath": "resourceFile3595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3596", + "filePath": "resourceFile3596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3597", + "filePath": "resourceFile3597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3598", + "filePath": "resourceFile3598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3599", + "filePath": "resourceFile3599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3600", + "filePath": "resourceFile3600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3601", + "filePath": "resourceFile3601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3602", + "filePath": "resourceFile3602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3603", + "filePath": "resourceFile3603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3604", + "filePath": "resourceFile3604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3605", + "filePath": "resourceFile3605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3606", + "filePath": "resourceFile3606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3607", + "filePath": "resourceFile3607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3608", + "filePath": "resourceFile3608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3609", + "filePath": "resourceFile3609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3610", + "filePath": "resourceFile3610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3611", + "filePath": "resourceFile3611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3612", + "filePath": "resourceFile3612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3613", + "filePath": "resourceFile3613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3614", + "filePath": "resourceFile3614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3615", + "filePath": "resourceFile3615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3616", + "filePath": "resourceFile3616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3617", + "filePath": "resourceFile3617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3618", + "filePath": "resourceFile3618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3619", + "filePath": "resourceFile3619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3620", + "filePath": "resourceFile3620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3621", + "filePath": "resourceFile3621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3622", + "filePath": "resourceFile3622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3623", + "filePath": "resourceFile3623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3624", + "filePath": "resourceFile3624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3625", + "filePath": "resourceFile3625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3626", + "filePath": "resourceFile3626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3627", + "filePath": "resourceFile3627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3628", + "filePath": "resourceFile3628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3629", + "filePath": "resourceFile3629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3630", + "filePath": "resourceFile3630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3631", + "filePath": "resourceFile3631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3632", + "filePath": "resourceFile3632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3633", + "filePath": "resourceFile3633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3634", + "filePath": "resourceFile3634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3635", + "filePath": "resourceFile3635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3636", + "filePath": "resourceFile3636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3637", + "filePath": "resourceFile3637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3638", + "filePath": "resourceFile3638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3639", + "filePath": "resourceFile3639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3640", + "filePath": "resourceFile3640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3641", + "filePath": "resourceFile3641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3642", + "filePath": "resourceFile3642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3643", + "filePath": "resourceFile3643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3644", + "filePath": "resourceFile3644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3645", + "filePath": "resourceFile3645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3646", + "filePath": "resourceFile3646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3647", + "filePath": "resourceFile3647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3648", + "filePath": "resourceFile3648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3649", + "filePath": "resourceFile3649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3650", + "filePath": "resourceFile3650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3651", + "filePath": "resourceFile3651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3652", + "filePath": "resourceFile3652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3653", + "filePath": "resourceFile3653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3654", + "filePath": "resourceFile3654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3655", + "filePath": "resourceFile3655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3656", + "filePath": "resourceFile3656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3657", + "filePath": "resourceFile3657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3658", + "filePath": "resourceFile3658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3659", + "filePath": "resourceFile3659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3660", + "filePath": "resourceFile3660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3661", + "filePath": "resourceFile3661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3662", + "filePath": "resourceFile3662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3663", + "filePath": "resourceFile3663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3664", + "filePath": "resourceFile3664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3665", + "filePath": "resourceFile3665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3666", + "filePath": "resourceFile3666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3667", + "filePath": "resourceFile3667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3668", + "filePath": "resourceFile3668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3669", + "filePath": "resourceFile3669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3670", + "filePath": "resourceFile3670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3671", + "filePath": "resourceFile3671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3672", + "filePath": "resourceFile3672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3673", + "filePath": "resourceFile3673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3674", + "filePath": "resourceFile3674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3675", + "filePath": "resourceFile3675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3676", + "filePath": "resourceFile3676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3677", + "filePath": "resourceFile3677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3678", + "filePath": "resourceFile3678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3679", + "filePath": "resourceFile3679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3680", + "filePath": "resourceFile3680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3681", + "filePath": "resourceFile3681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3682", + "filePath": "resourceFile3682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3683", + "filePath": "resourceFile3683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3684", + "filePath": "resourceFile3684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3685", + "filePath": "resourceFile3685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3686", + "filePath": "resourceFile3686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3687", + "filePath": "resourceFile3687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3688", + "filePath": "resourceFile3688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3689", + "filePath": "resourceFile3689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3690", + "filePath": "resourceFile3690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3691", + "filePath": "resourceFile3691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3692", + "filePath": "resourceFile3692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3693", + "filePath": "resourceFile3693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3694", + "filePath": "resourceFile3694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3695", + "filePath": "resourceFile3695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3696", + "filePath": "resourceFile3696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3697", + "filePath": "resourceFile3697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3698", + "filePath": "resourceFile3698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3699", + "filePath": "resourceFile3699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3700", + "filePath": "resourceFile3700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3701", + "filePath": "resourceFile3701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3702", + "filePath": "resourceFile3702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3703", + "filePath": "resourceFile3703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3704", + "filePath": "resourceFile3704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3705", + "filePath": "resourceFile3705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3706", + "filePath": "resourceFile3706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3707", + "filePath": "resourceFile3707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3708", + "filePath": "resourceFile3708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3709", + "filePath": "resourceFile3709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3710", + "filePath": "resourceFile3710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3711", + "filePath": "resourceFile3711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3712", + "filePath": "resourceFile3712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3713", + "filePath": "resourceFile3713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3714", + "filePath": "resourceFile3714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3715", + "filePath": "resourceFile3715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3716", + "filePath": "resourceFile3716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3717", + "filePath": "resourceFile3717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3718", + "filePath": "resourceFile3718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3719", + "filePath": "resourceFile3719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3720", + "filePath": "resourceFile3720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3721", + "filePath": "resourceFile3721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3722", + "filePath": "resourceFile3722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3723", + "filePath": "resourceFile3723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3724", + "filePath": "resourceFile3724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3725", + "filePath": "resourceFile3725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3726", + "filePath": "resourceFile3726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3727", + "filePath": "resourceFile3727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3728", + "filePath": "resourceFile3728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3729", + "filePath": "resourceFile3729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3730", + "filePath": "resourceFile3730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3731", + "filePath": "resourceFile3731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3732", + "filePath": "resourceFile3732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3733", + "filePath": "resourceFile3733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3734", + "filePath": "resourceFile3734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3735", + "filePath": "resourceFile3735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3736", + "filePath": "resourceFile3736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3737", + "filePath": "resourceFile3737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3738", + "filePath": "resourceFile3738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3739", + "filePath": "resourceFile3739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3740", + "filePath": "resourceFile3740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3741", + "filePath": "resourceFile3741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3742", + "filePath": "resourceFile3742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3743", + "filePath": "resourceFile3743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3744", + "filePath": "resourceFile3744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3745", + "filePath": "resourceFile3745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3746", + "filePath": "resourceFile3746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3747", + "filePath": "resourceFile3747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3748", + "filePath": "resourceFile3748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3749", + "filePath": "resourceFile3749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3750", + "filePath": "resourceFile3750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3751", + "filePath": "resourceFile3751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3752", + "filePath": "resourceFile3752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3753", + "filePath": "resourceFile3753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3754", + "filePath": "resourceFile3754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3755", + "filePath": "resourceFile3755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3756", + "filePath": "resourceFile3756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3757", + "filePath": "resourceFile3757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3758", + "filePath": "resourceFile3758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3759", + "filePath": "resourceFile3759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3760", + "filePath": "resourceFile3760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3761", + "filePath": "resourceFile3761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3762", + "filePath": "resourceFile3762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3763", + "filePath": "resourceFile3763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3764", + "filePath": "resourceFile3764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3765", + "filePath": "resourceFile3765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3766", + "filePath": "resourceFile3766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3767", + "filePath": "resourceFile3767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3768", + "filePath": "resourceFile3768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3769", + "filePath": "resourceFile3769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3770", + "filePath": "resourceFile3770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3771", + "filePath": "resourceFile3771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3772", + "filePath": "resourceFile3772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3773", + "filePath": "resourceFile3773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3774", + "filePath": "resourceFile3774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3775", + "filePath": "resourceFile3775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3776", + "filePath": "resourceFile3776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3777", + "filePath": "resourceFile3777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3778", + "filePath": "resourceFile3778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3779", + "filePath": "resourceFile3779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3780", + "filePath": "resourceFile3780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3781", + "filePath": "resourceFile3781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3782", + "filePath": "resourceFile3782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3783", + "filePath": "resourceFile3783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3784", + "filePath": "resourceFile3784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3785", + "filePath": "resourceFile3785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3786", + "filePath": "resourceFile3786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3787", + "filePath": "resourceFile3787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3788", + "filePath": "resourceFile3788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3789", + "filePath": "resourceFile3789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3790", + "filePath": "resourceFile3790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3791", + "filePath": "resourceFile3791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3792", + "filePath": "resourceFile3792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3793", + "filePath": "resourceFile3793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3794", + "filePath": "resourceFile3794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3795", + "filePath": "resourceFile3795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3796", + "filePath": "resourceFile3796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3797", + "filePath": "resourceFile3797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3798", + "filePath": "resourceFile3798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3799", + "filePath": "resourceFile3799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3800", + "filePath": "resourceFile3800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3801", + "filePath": "resourceFile3801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3802", + "filePath": "resourceFile3802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3803", + "filePath": "resourceFile3803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3804", + "filePath": "resourceFile3804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3805", + "filePath": "resourceFile3805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3806", + "filePath": "resourceFile3806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3807", + "filePath": "resourceFile3807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3808", + "filePath": "resourceFile3808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3809", + "filePath": "resourceFile3809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3810", + "filePath": "resourceFile3810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3811", + "filePath": "resourceFile3811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3812", + "filePath": "resourceFile3812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3813", + "filePath": "resourceFile3813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3814", + "filePath": "resourceFile3814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3815", + "filePath": "resourceFile3815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3816", + "filePath": "resourceFile3816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3817", + "filePath": "resourceFile3817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3818", + "filePath": "resourceFile3818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3819", + "filePath": "resourceFile3819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3820", + "filePath": "resourceFile3820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3821", + "filePath": "resourceFile3821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3822", + "filePath": "resourceFile3822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3823", + "filePath": "resourceFile3823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3824", + "filePath": "resourceFile3824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3825", + "filePath": "resourceFile3825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3826", + "filePath": "resourceFile3826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3827", + "filePath": "resourceFile3827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3828", + "filePath": "resourceFile3828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3829", + "filePath": "resourceFile3829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3830", + "filePath": "resourceFile3830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3831", + "filePath": "resourceFile3831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3832", + "filePath": "resourceFile3832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3833", + "filePath": "resourceFile3833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3834", + "filePath": "resourceFile3834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3835", + "filePath": "resourceFile3835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3836", + "filePath": "resourceFile3836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3837", + "filePath": "resourceFile3837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3838", + "filePath": "resourceFile3838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3839", + "filePath": "resourceFile3839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3840", + "filePath": "resourceFile3840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3841", + "filePath": "resourceFile3841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3842", + "filePath": "resourceFile3842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3843", + "filePath": "resourceFile3843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3844", + "filePath": "resourceFile3844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3845", + "filePath": "resourceFile3845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3846", + "filePath": "resourceFile3846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3847", + "filePath": "resourceFile3847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3848", + "filePath": "resourceFile3848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3849", + "filePath": "resourceFile3849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3850", + "filePath": "resourceFile3850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3851", + "filePath": "resourceFile3851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3852", + "filePath": "resourceFile3852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3853", + "filePath": "resourceFile3853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3854", + "filePath": "resourceFile3854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3855", + "filePath": "resourceFile3855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3856", + "filePath": "resourceFile3856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3857", + "filePath": "resourceFile3857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3858", + "filePath": "resourceFile3858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3859", + "filePath": "resourceFile3859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3860", + "filePath": "resourceFile3860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3861", + "filePath": "resourceFile3861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3862", + "filePath": "resourceFile3862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3863", + "filePath": "resourceFile3863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3864", + "filePath": "resourceFile3864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3865", + "filePath": "resourceFile3865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3866", + "filePath": "resourceFile3866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3867", + "filePath": "resourceFile3867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3868", + "filePath": "resourceFile3868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3869", + "filePath": "resourceFile3869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3870", + "filePath": "resourceFile3870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3871", + "filePath": "resourceFile3871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3872", + "filePath": "resourceFile3872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3873", + "filePath": "resourceFile3873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3874", + "filePath": "resourceFile3874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3875", + "filePath": "resourceFile3875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3876", + "filePath": "resourceFile3876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3877", + "filePath": "resourceFile3877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3878", + "filePath": "resourceFile3878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3879", + "filePath": "resourceFile3879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3880", + "filePath": "resourceFile3880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3881", + "filePath": "resourceFile3881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3882", + "filePath": "resourceFile3882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3883", + "filePath": "resourceFile3883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3884", + "filePath": "resourceFile3884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3885", + "filePath": "resourceFile3885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3886", + "filePath": "resourceFile3886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3887", + "filePath": "resourceFile3887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3888", + "filePath": "resourceFile3888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3889", + "filePath": "resourceFile3889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3890", + "filePath": "resourceFile3890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3891", + "filePath": "resourceFile3891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3892", + "filePath": "resourceFile3892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3893", + "filePath": "resourceFile3893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3894", + "filePath": "resourceFile3894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3895", + "filePath": "resourceFile3895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3896", + "filePath": "resourceFile3896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3897", + "filePath": "resourceFile3897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3898", + "filePath": "resourceFile3898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3899", + "filePath": "resourceFile3899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3900", + "filePath": "resourceFile3900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3901", + "filePath": "resourceFile3901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3902", + "filePath": "resourceFile3902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3903", + "filePath": "resourceFile3903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3904", + "filePath": "resourceFile3904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3905", + "filePath": "resourceFile3905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3906", + "filePath": "resourceFile3906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3907", + "filePath": "resourceFile3907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3908", + "filePath": "resourceFile3908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3909", + "filePath": "resourceFile3909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3910", + "filePath": "resourceFile3910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3911", + "filePath": "resourceFile3911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3912", + "filePath": "resourceFile3912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3913", + "filePath": "resourceFile3913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3914", + "filePath": "resourceFile3914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3915", + "filePath": "resourceFile3915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3916", + "filePath": "resourceFile3916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3917", + "filePath": "resourceFile3917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3918", + "filePath": "resourceFile3918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3919", + "filePath": "resourceFile3919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3920", + "filePath": "resourceFile3920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3921", + "filePath": "resourceFile3921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3922", + "filePath": "resourceFile3922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3923", + "filePath": "resourceFile3923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3924", + "filePath": "resourceFile3924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3925", + "filePath": "resourceFile3925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3926", + "filePath": "resourceFile3926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3927", + "filePath": "resourceFile3927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3928", + "filePath": "resourceFile3928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3929", + "filePath": "resourceFile3929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3930", + "filePath": "resourceFile3930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3931", + "filePath": "resourceFile3931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3932", + "filePath": "resourceFile3932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3933", + "filePath": "resourceFile3933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3934", + "filePath": "resourceFile3934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3935", + "filePath": "resourceFile3935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3936", + "filePath": "resourceFile3936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3937", + "filePath": "resourceFile3937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3938", + "filePath": "resourceFile3938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3939", + "filePath": "resourceFile3939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3940", + "filePath": "resourceFile3940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3941", + "filePath": "resourceFile3941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3942", + "filePath": "resourceFile3942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3943", + "filePath": "resourceFile3943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3944", + "filePath": "resourceFile3944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3945", + "filePath": "resourceFile3945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3946", + "filePath": "resourceFile3946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3947", + "filePath": "resourceFile3947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3948", + "filePath": "resourceFile3948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3949", + "filePath": "resourceFile3949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3950", + "filePath": "resourceFile3950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3951", + "filePath": "resourceFile3951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3952", + "filePath": "resourceFile3952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3953", + "filePath": "resourceFile3953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3954", + "filePath": "resourceFile3954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3955", + "filePath": "resourceFile3955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3956", + "filePath": "resourceFile3956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3957", + "filePath": "resourceFile3957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3958", + "filePath": "resourceFile3958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3959", + "filePath": "resourceFile3959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3960", + "filePath": "resourceFile3960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3961", + "filePath": "resourceFile3961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3962", + "filePath": "resourceFile3962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3963", + "filePath": "resourceFile3963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3964", + "filePath": "resourceFile3964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3965", + "filePath": "resourceFile3965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3966", + "filePath": "resourceFile3966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3967", + "filePath": "resourceFile3967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3968", + "filePath": "resourceFile3968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3969", + "filePath": "resourceFile3969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3970", + "filePath": "resourceFile3970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3971", + "filePath": "resourceFile3971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3972", + "filePath": "resourceFile3972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3973", + "filePath": "resourceFile3973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3974", + "filePath": "resourceFile3974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3975", + "filePath": "resourceFile3975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3976", + "filePath": "resourceFile3976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3977", + "filePath": "resourceFile3977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3978", + "filePath": "resourceFile3978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3979", + "filePath": "resourceFile3979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3980", + "filePath": "resourceFile3980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3981", + "filePath": "resourceFile3981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3982", + "filePath": "resourceFile3982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3983", + "filePath": "resourceFile3983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3984", + "filePath": "resourceFile3984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3985", + "filePath": "resourceFile3985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3986", + "filePath": "resourceFile3986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3987", + "filePath": "resourceFile3987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3988", + "filePath": "resourceFile3988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3989", + "filePath": "resourceFile3989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3990", + "filePath": "resourceFile3990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3991", + "filePath": "resourceFile3991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3992", + "filePath": "resourceFile3992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3993", + "filePath": "resourceFile3993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3994", + "filePath": "resourceFile3994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3995", + "filePath": "resourceFile3995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3996", + "filePath": "resourceFile3996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3997", + "filePath": "resourceFile3997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3998", + "filePath": "resourceFile3998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3999", + "filePath": "resourceFile3999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4000", + "filePath": "resourceFile4000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4001", + "filePath": "resourceFile4001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4002", + "filePath": "resourceFile4002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4003", + "filePath": "resourceFile4003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4004", + "filePath": "resourceFile4004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4005", + "filePath": "resourceFile4005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4006", + "filePath": "resourceFile4006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4007", + "filePath": "resourceFile4007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4008", + "filePath": "resourceFile4008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4009", + "filePath": "resourceFile4009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4010", + "filePath": "resourceFile4010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4011", + "filePath": "resourceFile4011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4012", + "filePath": "resourceFile4012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4013", + "filePath": "resourceFile4013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4014", + "filePath": "resourceFile4014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4015", + "filePath": "resourceFile4015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4016", + "filePath": "resourceFile4016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4017", + "filePath": "resourceFile4017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4018", + "filePath": "resourceFile4018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4019", + "filePath": "resourceFile4019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4020", + "filePath": "resourceFile4020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4021", + "filePath": "resourceFile4021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4022", + "filePath": "resourceFile4022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4023", + "filePath": "resourceFile4023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4024", + "filePath": "resourceFile4024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4025", + "filePath": "resourceFile4025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4026", + "filePath": "resourceFile4026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4027", + "filePath": "resourceFile4027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4028", + "filePath": "resourceFile4028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4029", + "filePath": "resourceFile4029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4030", + "filePath": "resourceFile4030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4031", + "filePath": "resourceFile4031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4032", + "filePath": "resourceFile4032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4033", + "filePath": "resourceFile4033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4034", + "filePath": "resourceFile4034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4035", + "filePath": "resourceFile4035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4036", + "filePath": "resourceFile4036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4037", + "filePath": "resourceFile4037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4038", + "filePath": "resourceFile4038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4039", + "filePath": "resourceFile4039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4040", + "filePath": "resourceFile4040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4041", + "filePath": "resourceFile4041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4042", + "filePath": "resourceFile4042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4043", + "filePath": "resourceFile4043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4044", + "filePath": "resourceFile4044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4045", + "filePath": "resourceFile4045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4046", + "filePath": "resourceFile4046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4047", + "filePath": "resourceFile4047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4048", + "filePath": "resourceFile4048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4049", + "filePath": "resourceFile4049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4050", + "filePath": "resourceFile4050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4051", + "filePath": "resourceFile4051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4052", + "filePath": "resourceFile4052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4053", + "filePath": "resourceFile4053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4054", + "filePath": "resourceFile4054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4055", + "filePath": "resourceFile4055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4056", + "filePath": "resourceFile4056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4057", + "filePath": "resourceFile4057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4058", + "filePath": "resourceFile4058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4059", + "filePath": "resourceFile4059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4060", + "filePath": "resourceFile4060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4061", + "filePath": "resourceFile4061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4062", + "filePath": "resourceFile4062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4063", + "filePath": "resourceFile4063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4064", + "filePath": "resourceFile4064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4065", + "filePath": "resourceFile4065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4066", + "filePath": "resourceFile4066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4067", + "filePath": "resourceFile4067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4068", + "filePath": "resourceFile4068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4069", + "filePath": "resourceFile4069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4070", + "filePath": "resourceFile4070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4071", + "filePath": "resourceFile4071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4072", + "filePath": "resourceFile4072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4073", + "filePath": "resourceFile4073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4074", + "filePath": "resourceFile4074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4075", + "filePath": "resourceFile4075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4076", + "filePath": "resourceFile4076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4077", + "filePath": "resourceFile4077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4078", + "filePath": "resourceFile4078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4079", + "filePath": "resourceFile4079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4080", + "filePath": "resourceFile4080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4081", + "filePath": "resourceFile4081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4082", + "filePath": "resourceFile4082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4083", + "filePath": "resourceFile4083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4084", + "filePath": "resourceFile4084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4085", + "filePath": "resourceFile4085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4086", + "filePath": "resourceFile4086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4087", + "filePath": "resourceFile4087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4088", + "filePath": "resourceFile4088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4089", + "filePath": "resourceFile4089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4090", + "filePath": "resourceFile4090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4091", + "filePath": "resourceFile4091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4092", + "filePath": "resourceFile4092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4093", + "filePath": "resourceFile4093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4094", + "filePath": "resourceFile4094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4095", + "filePath": "resourceFile4095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4096", + "filePath": "resourceFile4096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4097", + "filePath": "resourceFile4097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4098", + "filePath": "resourceFile4098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4099", + "filePath": "resourceFile4099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4100", + "filePath": "resourceFile4100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4101", + "filePath": "resourceFile4101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4102", + "filePath": "resourceFile4102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4103", + "filePath": "resourceFile4103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4104", + "filePath": "resourceFile4104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4105", + "filePath": "resourceFile4105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4106", + "filePath": "resourceFile4106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4107", + "filePath": "resourceFile4107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4108", + "filePath": "resourceFile4108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4109", + "filePath": "resourceFile4109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4110", + "filePath": "resourceFile4110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4111", + "filePath": "resourceFile4111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4112", + "filePath": "resourceFile4112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4113", + "filePath": "resourceFile4113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4114", + "filePath": "resourceFile4114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4115", + "filePath": "resourceFile4115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4116", + "filePath": "resourceFile4116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4117", + "filePath": "resourceFile4117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4118", + "filePath": "resourceFile4118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4119", + "filePath": "resourceFile4119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4120", + "filePath": "resourceFile4120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4121", + "filePath": "resourceFile4121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4122", + "filePath": "resourceFile4122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4123", + "filePath": "resourceFile4123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4124", + "filePath": "resourceFile4124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4125", + "filePath": "resourceFile4125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4126", + "filePath": "resourceFile4126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4127", + "filePath": "resourceFile4127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4128", + "filePath": "resourceFile4128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4129", + "filePath": "resourceFile4129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4130", + "filePath": "resourceFile4130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4131", + "filePath": "resourceFile4131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4132", + "filePath": "resourceFile4132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4133", + "filePath": "resourceFile4133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4134", + "filePath": "resourceFile4134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4135", + "filePath": "resourceFile4135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4136", + "filePath": "resourceFile4136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4137", + "filePath": "resourceFile4137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4138", + "filePath": "resourceFile4138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4139", + "filePath": "resourceFile4139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4140", + "filePath": "resourceFile4140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4141", + "filePath": "resourceFile4141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4142", + "filePath": "resourceFile4142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4143", + "filePath": "resourceFile4143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4144", + "filePath": "resourceFile4144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4145", + "filePath": "resourceFile4145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4146", + "filePath": "resourceFile4146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4147", + "filePath": "resourceFile4147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4148", + "filePath": "resourceFile4148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4149", + "filePath": "resourceFile4149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4150", + "filePath": "resourceFile4150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4151", + "filePath": "resourceFile4151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4152", + "filePath": "resourceFile4152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4153", + "filePath": "resourceFile4153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4154", + "filePath": "resourceFile4154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4155", + "filePath": "resourceFile4155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4156", + "filePath": "resourceFile4156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4157", + "filePath": "resourceFile4157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4158", + "filePath": "resourceFile4158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4159", + "filePath": "resourceFile4159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4160", + "filePath": "resourceFile4160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4161", + "filePath": "resourceFile4161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4162", + "filePath": "resourceFile4162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4163", + "filePath": "resourceFile4163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4164", + "filePath": "resourceFile4164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4165", + "filePath": "resourceFile4165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4166", + "filePath": "resourceFile4166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4167", + "filePath": "resourceFile4167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4168", + "filePath": "resourceFile4168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4169", + "filePath": "resourceFile4169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4170", + "filePath": "resourceFile4170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4171", + "filePath": "resourceFile4171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4172", + "filePath": "resourceFile4172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4173", + "filePath": "resourceFile4173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4174", + "filePath": "resourceFile4174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4175", + "filePath": "resourceFile4175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4176", + "filePath": "resourceFile4176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4177", + "filePath": "resourceFile4177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4178", + "filePath": "resourceFile4178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4179", + "filePath": "resourceFile4179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4180", + "filePath": "resourceFile4180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4181", + "filePath": "resourceFile4181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4182", + "filePath": "resourceFile4182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4183", + "filePath": "resourceFile4183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4184", + "filePath": "resourceFile4184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4185", + "filePath": "resourceFile4185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4186", + "filePath": "resourceFile4186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4187", + "filePath": "resourceFile4187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4188", + "filePath": "resourceFile4188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4189", + "filePath": "resourceFile4189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4190", + "filePath": "resourceFile4190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4191", + "filePath": "resourceFile4191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4192", + "filePath": "resourceFile4192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4193", + "filePath": "resourceFile4193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4194", + "filePath": "resourceFile4194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4195", + "filePath": "resourceFile4195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4196", + "filePath": "resourceFile4196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4197", + "filePath": "resourceFile4197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4198", + "filePath": "resourceFile4198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4199", + "filePath": "resourceFile4199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4200", + "filePath": "resourceFile4200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4201", + "filePath": "resourceFile4201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4202", + "filePath": "resourceFile4202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4203", + "filePath": "resourceFile4203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4204", + "filePath": "resourceFile4204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4205", + "filePath": "resourceFile4205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4206", + "filePath": "resourceFile4206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4207", + "filePath": "resourceFile4207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4208", + "filePath": "resourceFile4208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4209", + "filePath": "resourceFile4209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4210", + "filePath": "resourceFile4210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4211", + "filePath": "resourceFile4211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4212", + "filePath": "resourceFile4212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4213", + "filePath": "resourceFile4213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4214", + "filePath": "resourceFile4214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4215", + "filePath": "resourceFile4215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4216", + "filePath": "resourceFile4216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4217", + "filePath": "resourceFile4217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4218", + "filePath": "resourceFile4218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4219", + "filePath": "resourceFile4219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4220", + "filePath": "resourceFile4220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4221", + "filePath": "resourceFile4221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4222", + "filePath": "resourceFile4222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4223", + "filePath": "resourceFile4223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4224", + "filePath": "resourceFile4224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4225", + "filePath": "resourceFile4225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4226", + "filePath": "resourceFile4226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4227", + "filePath": "resourceFile4227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4228", + "filePath": "resourceFile4228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4229", + "filePath": "resourceFile4229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4230", + "filePath": "resourceFile4230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4231", + "filePath": "resourceFile4231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4232", + "filePath": "resourceFile4232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4233", + "filePath": "resourceFile4233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4234", + "filePath": "resourceFile4234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4235", + "filePath": "resourceFile4235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4236", + "filePath": "resourceFile4236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4237", + "filePath": "resourceFile4237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4238", + "filePath": "resourceFile4238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4239", + "filePath": "resourceFile4239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4240", + "filePath": "resourceFile4240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4241", + "filePath": "resourceFile4241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4242", + "filePath": "resourceFile4242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4243", + "filePath": "resourceFile4243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4244", + "filePath": "resourceFile4244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4245", + "filePath": "resourceFile4245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4246", + "filePath": "resourceFile4246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4247", + "filePath": "resourceFile4247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4248", + "filePath": "resourceFile4248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4249", + "filePath": "resourceFile4249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4250", + "filePath": "resourceFile4250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4251", + "filePath": "resourceFile4251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4252", + "filePath": "resourceFile4252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4253", + "filePath": "resourceFile4253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4254", + "filePath": "resourceFile4254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4255", + "filePath": "resourceFile4255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4256", + "filePath": "resourceFile4256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4257", + "filePath": "resourceFile4257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4258", + "filePath": "resourceFile4258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4259", + "filePath": "resourceFile4259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4260", + "filePath": "resourceFile4260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4261", + "filePath": "resourceFile4261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4262", + "filePath": "resourceFile4262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4263", + "filePath": "resourceFile4263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4264", + "filePath": "resourceFile4264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4265", + "filePath": "resourceFile4265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4266", + "filePath": "resourceFile4266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4267", + "filePath": "resourceFile4267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4268", + "filePath": "resourceFile4268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4269", + "filePath": "resourceFile4269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4270", + "filePath": "resourceFile4270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4271", + "filePath": "resourceFile4271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4272", + "filePath": "resourceFile4272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4273", + "filePath": "resourceFile4273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4274", + "filePath": "resourceFile4274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4275", + "filePath": "resourceFile4275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4276", + "filePath": "resourceFile4276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4277", + "filePath": "resourceFile4277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4278", + "filePath": "resourceFile4278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4279", + "filePath": "resourceFile4279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4280", + "filePath": "resourceFile4280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4281", + "filePath": "resourceFile4281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4282", + "filePath": "resourceFile4282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4283", + "filePath": "resourceFile4283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4284", + "filePath": "resourceFile4284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4285", + "filePath": "resourceFile4285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4286", + "filePath": "resourceFile4286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4287", + "filePath": "resourceFile4287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4288", + "filePath": "resourceFile4288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4289", + "filePath": "resourceFile4289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4290", + "filePath": "resourceFile4290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4291", + "filePath": "resourceFile4291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4292", + "filePath": "resourceFile4292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4293", + "filePath": "resourceFile4293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4294", + "filePath": "resourceFile4294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4295", + "filePath": "resourceFile4295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4296", + "filePath": "resourceFile4296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4297", + "filePath": "resourceFile4297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4298", + "filePath": "resourceFile4298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4299", + "filePath": "resourceFile4299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4300", + "filePath": "resourceFile4300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4301", + "filePath": "resourceFile4301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4302", + "filePath": "resourceFile4302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4303", + "filePath": "resourceFile4303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4304", + "filePath": "resourceFile4304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4305", + "filePath": "resourceFile4305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4306", + "filePath": "resourceFile4306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4307", + "filePath": "resourceFile4307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4308", + "filePath": "resourceFile4308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4309", + "filePath": "resourceFile4309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4310", + "filePath": "resourceFile4310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4311", + "filePath": "resourceFile4311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4312", + "filePath": "resourceFile4312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4313", + "filePath": "resourceFile4313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4314", + "filePath": "resourceFile4314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4315", + "filePath": "resourceFile4315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4316", + "filePath": "resourceFile4316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4317", + "filePath": "resourceFile4317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4318", + "filePath": "resourceFile4318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4319", + "filePath": "resourceFile4319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4320", + "filePath": "resourceFile4320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4321", + "filePath": "resourceFile4321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4322", + "filePath": "resourceFile4322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4323", + "filePath": "resourceFile4323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4324", + "filePath": "resourceFile4324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4325", + "filePath": "resourceFile4325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4326", + "filePath": "resourceFile4326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4327", + "filePath": "resourceFile4327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4328", + "filePath": "resourceFile4328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4329", + "filePath": "resourceFile4329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4330", + "filePath": "resourceFile4330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4331", + "filePath": "resourceFile4331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4332", + "filePath": "resourceFile4332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4333", + "filePath": "resourceFile4333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4334", + "filePath": "resourceFile4334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4335", + "filePath": "resourceFile4335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4336", + "filePath": "resourceFile4336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4337", + "filePath": "resourceFile4337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4338", + "filePath": "resourceFile4338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4339", + "filePath": "resourceFile4339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4340", + "filePath": "resourceFile4340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4341", + "filePath": "resourceFile4341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4342", + "filePath": "resourceFile4342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4343", + "filePath": "resourceFile4343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4344", + "filePath": "resourceFile4344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4345", + "filePath": "resourceFile4345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4346", + "filePath": "resourceFile4346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4347", + "filePath": "resourceFile4347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4348", + "filePath": "resourceFile4348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4349", + "filePath": "resourceFile4349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4350", + "filePath": "resourceFile4350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4351", + "filePath": "resourceFile4351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4352", + "filePath": "resourceFile4352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4353", + "filePath": "resourceFile4353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4354", + "filePath": "resourceFile4354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4355", + "filePath": "resourceFile4355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4356", + "filePath": "resourceFile4356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4357", + "filePath": "resourceFile4357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4358", + "filePath": "resourceFile4358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4359", + "filePath": "resourceFile4359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4360", + "filePath": "resourceFile4360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4361", + "filePath": "resourceFile4361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4362", + "filePath": "resourceFile4362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4363", + "filePath": "resourceFile4363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4364", + "filePath": "resourceFile4364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4365", + "filePath": "resourceFile4365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4366", + "filePath": "resourceFile4366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4367", + "filePath": "resourceFile4367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4368", + "filePath": "resourceFile4368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4369", + "filePath": "resourceFile4369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4370", + "filePath": "resourceFile4370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4371", + "filePath": "resourceFile4371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4372", + "filePath": "resourceFile4372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4373", + "filePath": "resourceFile4373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4374", + "filePath": "resourceFile4374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4375", + "filePath": "resourceFile4375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4376", + "filePath": "resourceFile4376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4377", + "filePath": "resourceFile4377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4378", + "filePath": "resourceFile4378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4379", + "filePath": "resourceFile4379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4380", + "filePath": "resourceFile4380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4381", + "filePath": "resourceFile4381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4382", + "filePath": "resourceFile4382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4383", + "filePath": "resourceFile4383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4384", + "filePath": "resourceFile4384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4385", + "filePath": "resourceFile4385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4386", + "filePath": "resourceFile4386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4387", + "filePath": "resourceFile4387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4388", + "filePath": "resourceFile4388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4389", + "filePath": "resourceFile4389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4390", + "filePath": "resourceFile4390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4391", + "filePath": "resourceFile4391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4392", + "filePath": "resourceFile4392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4393", + "filePath": "resourceFile4393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4394", + "filePath": "resourceFile4394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4395", + "filePath": "resourceFile4395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4396", + "filePath": "resourceFile4396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4397", + "filePath": "resourceFile4397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4398", + "filePath": "resourceFile4398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4399", + "filePath": "resourceFile4399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4400", + "filePath": "resourceFile4400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4401", + "filePath": "resourceFile4401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4402", + "filePath": "resourceFile4402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4403", + "filePath": "resourceFile4403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4404", + "filePath": "resourceFile4404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4405", + "filePath": "resourceFile4405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4406", + "filePath": "resourceFile4406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4407", + "filePath": "resourceFile4407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4408", + "filePath": "resourceFile4408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4409", + "filePath": "resourceFile4409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4410", + "filePath": "resourceFile4410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4411", + "filePath": "resourceFile4411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4412", + "filePath": "resourceFile4412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4413", + "filePath": "resourceFile4413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4414", + "filePath": "resourceFile4414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4415", + "filePath": "resourceFile4415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4416", + "filePath": "resourceFile4416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4417", + "filePath": "resourceFile4417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4418", + "filePath": "resourceFile4418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4419", + "filePath": "resourceFile4419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4420", + "filePath": "resourceFile4420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4421", + "filePath": "resourceFile4421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4422", + "filePath": "resourceFile4422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4423", + "filePath": "resourceFile4423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4424", + "filePath": "resourceFile4424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4425", + "filePath": "resourceFile4425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4426", + "filePath": "resourceFile4426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4427", + "filePath": "resourceFile4427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4428", + "filePath": "resourceFile4428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4429", + "filePath": "resourceFile4429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4430", + "filePath": "resourceFile4430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4431", + "filePath": "resourceFile4431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4432", + "filePath": "resourceFile4432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4433", + "filePath": "resourceFile4433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4434", + "filePath": "resourceFile4434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4435", + "filePath": "resourceFile4435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4436", + "filePath": "resourceFile4436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4437", + "filePath": "resourceFile4437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4438", + "filePath": "resourceFile4438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4439", + "filePath": "resourceFile4439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4440", + "filePath": "resourceFile4440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4441", + "filePath": "resourceFile4441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4442", + "filePath": "resourceFile4442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4443", + "filePath": "resourceFile4443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4444", + "filePath": "resourceFile4444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4445", + "filePath": "resourceFile4445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4446", + "filePath": "resourceFile4446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4447", + "filePath": "resourceFile4447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4448", + "filePath": "resourceFile4448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4449", + "filePath": "resourceFile4449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4450", + "filePath": "resourceFile4450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4451", + "filePath": "resourceFile4451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4452", + "filePath": "resourceFile4452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4453", + "filePath": "resourceFile4453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4454", + "filePath": "resourceFile4454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4455", + "filePath": "resourceFile4455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4456", + "filePath": "resourceFile4456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4457", + "filePath": "resourceFile4457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4458", + "filePath": "resourceFile4458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4459", + "filePath": "resourceFile4459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4460", + "filePath": "resourceFile4460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4461", + "filePath": "resourceFile4461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4462", + "filePath": "resourceFile4462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4463", + "filePath": "resourceFile4463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4464", + "filePath": "resourceFile4464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4465", + "filePath": "resourceFile4465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4466", + "filePath": "resourceFile4466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4467", + "filePath": "resourceFile4467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4468", + "filePath": "resourceFile4468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4469", + "filePath": "resourceFile4469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4470", + "filePath": "resourceFile4470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4471", + "filePath": "resourceFile4471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4472", + "filePath": "resourceFile4472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4473", + "filePath": "resourceFile4473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4474", + "filePath": "resourceFile4474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4475", + "filePath": "resourceFile4475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4476", + "filePath": "resourceFile4476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4477", + "filePath": "resourceFile4477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4478", + "filePath": "resourceFile4478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4479", + "filePath": "resourceFile4479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4480", + "filePath": "resourceFile4480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4481", + "filePath": "resourceFile4481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4482", + "filePath": "resourceFile4482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4483", + "filePath": "resourceFile4483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4484", + "filePath": "resourceFile4484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4485", + "filePath": "resourceFile4485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4486", + "filePath": "resourceFile4486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4487", + "filePath": "resourceFile4487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4488", + "filePath": "resourceFile4488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4489", + "filePath": "resourceFile4489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4490", + "filePath": "resourceFile4490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4491", + "filePath": "resourceFile4491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4492", + "filePath": "resourceFile4492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4493", + "filePath": "resourceFile4493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4494", + "filePath": "resourceFile4494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4495", + "filePath": "resourceFile4495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4496", + "filePath": "resourceFile4496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4497", + "filePath": "resourceFile4497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4498", + "filePath": "resourceFile4498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4499", + "filePath": "resourceFile4499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4500", + "filePath": "resourceFile4500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4501", + "filePath": "resourceFile4501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4502", + "filePath": "resourceFile4502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4503", + "filePath": "resourceFile4503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4504", + "filePath": "resourceFile4504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4505", + "filePath": "resourceFile4505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4506", + "filePath": "resourceFile4506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4507", + "filePath": "resourceFile4507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4508", + "filePath": "resourceFile4508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4509", + "filePath": "resourceFile4509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4510", + "filePath": "resourceFile4510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4511", + "filePath": "resourceFile4511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4512", + "filePath": "resourceFile4512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4513", + "filePath": "resourceFile4513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4514", + "filePath": "resourceFile4514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4515", + "filePath": "resourceFile4515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4516", + "filePath": "resourceFile4516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4517", + "filePath": "resourceFile4517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4518", + "filePath": "resourceFile4518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4519", + "filePath": "resourceFile4519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4520", + "filePath": "resourceFile4520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4521", + "filePath": "resourceFile4521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4522", + "filePath": "resourceFile4522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4523", + "filePath": "resourceFile4523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4524", + "filePath": "resourceFile4524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4525", + "filePath": "resourceFile4525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4526", + "filePath": "resourceFile4526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4527", + "filePath": "resourceFile4527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4528", + "filePath": "resourceFile4528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4529", + "filePath": "resourceFile4529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4530", + "filePath": "resourceFile4530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4531", + "filePath": "resourceFile4531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4532", + "filePath": "resourceFile4532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4533", + "filePath": "resourceFile4533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4534", + "filePath": "resourceFile4534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4535", + "filePath": "resourceFile4535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4536", + "filePath": "resourceFile4536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4537", + "filePath": "resourceFile4537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4538", + "filePath": "resourceFile4538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4539", + "filePath": "resourceFile4539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4540", + "filePath": "resourceFile4540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4541", + "filePath": "resourceFile4541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4542", + "filePath": "resourceFile4542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4543", + "filePath": "resourceFile4543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4544", + "filePath": "resourceFile4544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4545", + "filePath": "resourceFile4545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4546", + "filePath": "resourceFile4546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4547", + "filePath": "resourceFile4547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4548", + "filePath": "resourceFile4548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4549", + "filePath": "resourceFile4549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4550", + "filePath": "resourceFile4550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4551", + "filePath": "resourceFile4551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4552", + "filePath": "resourceFile4552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4553", + "filePath": "resourceFile4553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4554", + "filePath": "resourceFile4554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4555", + "filePath": "resourceFile4555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4556", + "filePath": "resourceFile4556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4557", + "filePath": "resourceFile4557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4558", + "filePath": "resourceFile4558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4559", + "filePath": "resourceFile4559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4560", + "filePath": "resourceFile4560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4561", + "filePath": "resourceFile4561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4562", + "filePath": "resourceFile4562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4563", + "filePath": "resourceFile4563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4564", + "filePath": "resourceFile4564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4565", + "filePath": "resourceFile4565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4566", + "filePath": "resourceFile4566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4567", + "filePath": "resourceFile4567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4568", + "filePath": "resourceFile4568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4569", + "filePath": "resourceFile4569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4570", + "filePath": "resourceFile4570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4571", + "filePath": "resourceFile4571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4572", + "filePath": "resourceFile4572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4573", + "filePath": "resourceFile4573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4574", + "filePath": "resourceFile4574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4575", + "filePath": "resourceFile4575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4576", + "filePath": "resourceFile4576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4577", + "filePath": "resourceFile4577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4578", + "filePath": "resourceFile4578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4579", + "filePath": "resourceFile4579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4580", + "filePath": "resourceFile4580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4581", + "filePath": "resourceFile4581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4582", + "filePath": "resourceFile4582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4583", + "filePath": "resourceFile4583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4584", + "filePath": "resourceFile4584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4585", + "filePath": "resourceFile4585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4586", + "filePath": "resourceFile4586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4587", + "filePath": "resourceFile4587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4588", + "filePath": "resourceFile4588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4589", + "filePath": "resourceFile4589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4590", + "filePath": "resourceFile4590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4591", + "filePath": "resourceFile4591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4592", + "filePath": "resourceFile4592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4593", + "filePath": "resourceFile4593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4594", + "filePath": "resourceFile4594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4595", + "filePath": "resourceFile4595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4596", + "filePath": "resourceFile4596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4597", + "filePath": "resourceFile4597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4598", + "filePath": "resourceFile4598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4599", + "filePath": "resourceFile4599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4600", + "filePath": "resourceFile4600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4601", + "filePath": "resourceFile4601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4602", + "filePath": "resourceFile4602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4603", + "filePath": "resourceFile4603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4604", + "filePath": "resourceFile4604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4605", + "filePath": "resourceFile4605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4606", + "filePath": "resourceFile4606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4607", + "filePath": "resourceFile4607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4608", + "filePath": "resourceFile4608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4609", + "filePath": "resourceFile4609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4610", + "filePath": "resourceFile4610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4611", + "filePath": "resourceFile4611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4612", + "filePath": "resourceFile4612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4613", + "filePath": "resourceFile4613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4614", + "filePath": "resourceFile4614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4615", + "filePath": "resourceFile4615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4616", + "filePath": "resourceFile4616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4617", + "filePath": "resourceFile4617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4618", + "filePath": "resourceFile4618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4619", + "filePath": "resourceFile4619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4620", + "filePath": "resourceFile4620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4621", + "filePath": "resourceFile4621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4622", + "filePath": "resourceFile4622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4623", + "filePath": "resourceFile4623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4624", + "filePath": "resourceFile4624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4625", + "filePath": "resourceFile4625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4626", + "filePath": "resourceFile4626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4627", + "filePath": "resourceFile4627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4628", + "filePath": "resourceFile4628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4629", + "filePath": "resourceFile4629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4630", + "filePath": "resourceFile4630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4631", + "filePath": "resourceFile4631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4632", + "filePath": "resourceFile4632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4633", + "filePath": "resourceFile4633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4634", + "filePath": "resourceFile4634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4635", + "filePath": "resourceFile4635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4636", + "filePath": "resourceFile4636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4637", + "filePath": "resourceFile4637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4638", + "filePath": "resourceFile4638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4639", + "filePath": "resourceFile4639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4640", + "filePath": "resourceFile4640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4641", + "filePath": "resourceFile4641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4642", + "filePath": "resourceFile4642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4643", + "filePath": "resourceFile4643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4644", + "filePath": "resourceFile4644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4645", + "filePath": "resourceFile4645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4646", + "filePath": "resourceFile4646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4647", + "filePath": "resourceFile4647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4648", + "filePath": "resourceFile4648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4649", + "filePath": "resourceFile4649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4650", + "filePath": "resourceFile4650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4651", + "filePath": "resourceFile4651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4652", + "filePath": "resourceFile4652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4653", + "filePath": "resourceFile4653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4654", + "filePath": "resourceFile4654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4655", + "filePath": "resourceFile4655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4656", + "filePath": "resourceFile4656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4657", + "filePath": "resourceFile4657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4658", + "filePath": "resourceFile4658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4659", + "filePath": "resourceFile4659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4660", + "filePath": "resourceFile4660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4661", + "filePath": "resourceFile4661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4662", + "filePath": "resourceFile4662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4663", + "filePath": "resourceFile4663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4664", + "filePath": "resourceFile4664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4665", + "filePath": "resourceFile4665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4666", + "filePath": "resourceFile4666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4667", + "filePath": "resourceFile4667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4668", + "filePath": "resourceFile4668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4669", + "filePath": "resourceFile4669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4670", + "filePath": "resourceFile4670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4671", + "filePath": "resourceFile4671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4672", + "filePath": "resourceFile4672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4673", + "filePath": "resourceFile4673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4674", + "filePath": "resourceFile4674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4675", + "filePath": "resourceFile4675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4676", + "filePath": "resourceFile4676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4677", + "filePath": "resourceFile4677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4678", + "filePath": "resourceFile4678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4679", + "filePath": "resourceFile4679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4680", + "filePath": "resourceFile4680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4681", + "filePath": "resourceFile4681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4682", + "filePath": "resourceFile4682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4683", + "filePath": "resourceFile4683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4684", + "filePath": "resourceFile4684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4685", + "filePath": "resourceFile4685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4686", + "filePath": "resourceFile4686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4687", + "filePath": "resourceFile4687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4688", + "filePath": "resourceFile4688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4689", + "filePath": "resourceFile4689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4690", + "filePath": "resourceFile4690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4691", + "filePath": "resourceFile4691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4692", + "filePath": "resourceFile4692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4693", + "filePath": "resourceFile4693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4694", + "filePath": "resourceFile4694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4695", + "filePath": "resourceFile4695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4696", + "filePath": "resourceFile4696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4697", + "filePath": "resourceFile4697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4698", + "filePath": "resourceFile4698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4699", + "filePath": "resourceFile4699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4700", + "filePath": "resourceFile4700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4701", + "filePath": "resourceFile4701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4702", + "filePath": "resourceFile4702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4703", + "filePath": "resourceFile4703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4704", + "filePath": "resourceFile4704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4705", + "filePath": "resourceFile4705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4706", + "filePath": "resourceFile4706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4707", + "filePath": "resourceFile4707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4708", + "filePath": "resourceFile4708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4709", + "filePath": "resourceFile4709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4710", + "filePath": "resourceFile4710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4711", + "filePath": "resourceFile4711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4712", + "filePath": "resourceFile4712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4713", + "filePath": "resourceFile4713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4714", + "filePath": "resourceFile4714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4715", + "filePath": "resourceFile4715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4716", + "filePath": "resourceFile4716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4717", + "filePath": "resourceFile4717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4718", + "filePath": "resourceFile4718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4719", + "filePath": "resourceFile4719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4720", + "filePath": "resourceFile4720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4721", + "filePath": "resourceFile4721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4722", + "filePath": "resourceFile4722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4723", + "filePath": "resourceFile4723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4724", + "filePath": "resourceFile4724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4725", + "filePath": "resourceFile4725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4726", + "filePath": "resourceFile4726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4727", + "filePath": "resourceFile4727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4728", + "filePath": "resourceFile4728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4729", + "filePath": "resourceFile4729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4730", + "filePath": "resourceFile4730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4731", + "filePath": "resourceFile4731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4732", + "filePath": "resourceFile4732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4733", + "filePath": "resourceFile4733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4734", + "filePath": "resourceFile4734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4735", + "filePath": "resourceFile4735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4736", + "filePath": "resourceFile4736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4737", + "filePath": "resourceFile4737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4738", + "filePath": "resourceFile4738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4739", + "filePath": "resourceFile4739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4740", + "filePath": "resourceFile4740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4741", + "filePath": "resourceFile4741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4742", + "filePath": "resourceFile4742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4743", + "filePath": "resourceFile4743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4744", + "filePath": "resourceFile4744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4745", + "filePath": "resourceFile4745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4746", + "filePath": "resourceFile4746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4747", + "filePath": "resourceFile4747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4748", + "filePath": "resourceFile4748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4749", + "filePath": "resourceFile4749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4750", + "filePath": "resourceFile4750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4751", + "filePath": "resourceFile4751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4752", + "filePath": "resourceFile4752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4753", + "filePath": "resourceFile4753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4754", + "filePath": "resourceFile4754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4755", + "filePath": "resourceFile4755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4756", + "filePath": "resourceFile4756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4757", + "filePath": "resourceFile4757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4758", + "filePath": "resourceFile4758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4759", + "filePath": "resourceFile4759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4760", + "filePath": "resourceFile4760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4761", + "filePath": "resourceFile4761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4762", + "filePath": "resourceFile4762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4763", + "filePath": "resourceFile4763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4764", + "filePath": "resourceFile4764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4765", + "filePath": "resourceFile4765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4766", + "filePath": "resourceFile4766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4767", + "filePath": "resourceFile4767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4768", + "filePath": "resourceFile4768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4769", + "filePath": "resourceFile4769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4770", + "filePath": "resourceFile4770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4771", + "filePath": "resourceFile4771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4772", + "filePath": "resourceFile4772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4773", + "filePath": "resourceFile4773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4774", + "filePath": "resourceFile4774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4775", + "filePath": "resourceFile4775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4776", + "filePath": "resourceFile4776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4777", + "filePath": "resourceFile4777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4778", + "filePath": "resourceFile4778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4779", + "filePath": "resourceFile4779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4780", + "filePath": "resourceFile4780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4781", + "filePath": "resourceFile4781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4782", + "filePath": "resourceFile4782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4783", + "filePath": "resourceFile4783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4784", + "filePath": "resourceFile4784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4785", + "filePath": "resourceFile4785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4786", + "filePath": "resourceFile4786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4787", + "filePath": "resourceFile4787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4788", + "filePath": "resourceFile4788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4789", + "filePath": "resourceFile4789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4790", + "filePath": "resourceFile4790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4791", + "filePath": "resourceFile4791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4792", + "filePath": "resourceFile4792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4793", + "filePath": "resourceFile4793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4794", + "filePath": "resourceFile4794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4795", + "filePath": "resourceFile4795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4796", + "filePath": "resourceFile4796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4797", + "filePath": "resourceFile4797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4798", + "filePath": "resourceFile4798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4799", + "filePath": "resourceFile4799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4800", + "filePath": "resourceFile4800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4801", + "filePath": "resourceFile4801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4802", + "filePath": "resourceFile4802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4803", + "filePath": "resourceFile4803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4804", + "filePath": "resourceFile4804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4805", + "filePath": "resourceFile4805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4806", + "filePath": "resourceFile4806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4807", + "filePath": "resourceFile4807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4808", + "filePath": "resourceFile4808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4809", + "filePath": "resourceFile4809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4810", + "filePath": "resourceFile4810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4811", + "filePath": "resourceFile4811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4812", + "filePath": "resourceFile4812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4813", + "filePath": "resourceFile4813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4814", + "filePath": "resourceFile4814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4815", + "filePath": "resourceFile4815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4816", + "filePath": "resourceFile4816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4817", + "filePath": "resourceFile4817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4818", + "filePath": "resourceFile4818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4819", + "filePath": "resourceFile4819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4820", + "filePath": "resourceFile4820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4821", + "filePath": "resourceFile4821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4822", + "filePath": "resourceFile4822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4823", + "filePath": "resourceFile4823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4824", + "filePath": "resourceFile4824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4825", + "filePath": "resourceFile4825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4826", + "filePath": "resourceFile4826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4827", + "filePath": "resourceFile4827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4828", + "filePath": "resourceFile4828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4829", + "filePath": "resourceFile4829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4830", + "filePath": "resourceFile4830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4831", + "filePath": "resourceFile4831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4832", + "filePath": "resourceFile4832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4833", + "filePath": "resourceFile4833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4834", + "filePath": "resourceFile4834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4835", + "filePath": "resourceFile4835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4836", + "filePath": "resourceFile4836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4837", + "filePath": "resourceFile4837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4838", + "filePath": "resourceFile4838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4839", + "filePath": "resourceFile4839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4840", + "filePath": "resourceFile4840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4841", + "filePath": "resourceFile4841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4842", + "filePath": "resourceFile4842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4843", + "filePath": "resourceFile4843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4844", + "filePath": "resourceFile4844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4845", + "filePath": "resourceFile4845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4846", + "filePath": "resourceFile4846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4847", + "filePath": "resourceFile4847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4848", + "filePath": "resourceFile4848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4849", + "filePath": "resourceFile4849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4850", + "filePath": "resourceFile4850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4851", + "filePath": "resourceFile4851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4852", + "filePath": "resourceFile4852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4853", + "filePath": "resourceFile4853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4854", + "filePath": "resourceFile4854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4855", + "filePath": "resourceFile4855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4856", + "filePath": "resourceFile4856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4857", + "filePath": "resourceFile4857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4858", + "filePath": "resourceFile4858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4859", + "filePath": "resourceFile4859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4860", + "filePath": "resourceFile4860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4861", + "filePath": "resourceFile4861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4862", + "filePath": "resourceFile4862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4863", + "filePath": "resourceFile4863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4864", + "filePath": "resourceFile4864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4865", + "filePath": "resourceFile4865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4866", + "filePath": "resourceFile4866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4867", + "filePath": "resourceFile4867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4868", + "filePath": "resourceFile4868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4869", + "filePath": "resourceFile4869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4870", + "filePath": "resourceFile4870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4871", + "filePath": "resourceFile4871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4872", + "filePath": "resourceFile4872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4873", + "filePath": "resourceFile4873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4874", + "filePath": "resourceFile4874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4875", + "filePath": "resourceFile4875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4876", + "filePath": "resourceFile4876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4877", + "filePath": "resourceFile4877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4878", + "filePath": "resourceFile4878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4879", + "filePath": "resourceFile4879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4880", + "filePath": "resourceFile4880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4881", + "filePath": "resourceFile4881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4882", + "filePath": "resourceFile4882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4883", + "filePath": "resourceFile4883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4884", + "filePath": "resourceFile4884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4885", + "filePath": "resourceFile4885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4886", + "filePath": "resourceFile4886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4887", + "filePath": "resourceFile4887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4888", + "filePath": "resourceFile4888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4889", + "filePath": "resourceFile4889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4890", + "filePath": "resourceFile4890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4891", + "filePath": "resourceFile4891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4892", + "filePath": "resourceFile4892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4893", + "filePath": "resourceFile4893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4894", + "filePath": "resourceFile4894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4895", + "filePath": "resourceFile4895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4896", + "filePath": "resourceFile4896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4897", + "filePath": "resourceFile4897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4898", + "filePath": "resourceFile4898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4899", + "filePath": "resourceFile4899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4900", + "filePath": "resourceFile4900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4901", + "filePath": "resourceFile4901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4902", + "filePath": "resourceFile4902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4903", + "filePath": "resourceFile4903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4904", + "filePath": "resourceFile4904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4905", + "filePath": "resourceFile4905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4906", + "filePath": "resourceFile4906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4907", + "filePath": "resourceFile4907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4908", + "filePath": "resourceFile4908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4909", + "filePath": "resourceFile4909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4910", + "filePath": "resourceFile4910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4911", + "filePath": "resourceFile4911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4912", + "filePath": "resourceFile4912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4913", + "filePath": "resourceFile4913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4914", + "filePath": "resourceFile4914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4915", + "filePath": "resourceFile4915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4916", + "filePath": "resourceFile4916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4917", + "filePath": "resourceFile4917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4918", + "filePath": "resourceFile4918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4919", + "filePath": "resourceFile4919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4920", + "filePath": "resourceFile4920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4921", + "filePath": "resourceFile4921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4922", + "filePath": "resourceFile4922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4923", + "filePath": "resourceFile4923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4924", + "filePath": "resourceFile4924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4925", + "filePath": "resourceFile4925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4926", + "filePath": "resourceFile4926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4927", + "filePath": "resourceFile4927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4928", + "filePath": "resourceFile4928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4929", + "filePath": "resourceFile4929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4930", + "filePath": "resourceFile4930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4931", + "filePath": "resourceFile4931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4932", + "filePath": "resourceFile4932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4933", + "filePath": "resourceFile4933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4934", + "filePath": "resourceFile4934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4935", + "filePath": "resourceFile4935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4936", + "filePath": "resourceFile4936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4937", + "filePath": "resourceFile4937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4938", + "filePath": "resourceFile4938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4939", + "filePath": "resourceFile4939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4940", + "filePath": "resourceFile4940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4941", + "filePath": "resourceFile4941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4942", + "filePath": "resourceFile4942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4943", + "filePath": "resourceFile4943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4944", + "filePath": "resourceFile4944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4945", + "filePath": "resourceFile4945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4946", + "filePath": "resourceFile4946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4947", + "filePath": "resourceFile4947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4948", + "filePath": "resourceFile4948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4949", + "filePath": "resourceFile4949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4950", + "filePath": "resourceFile4950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4951", + "filePath": "resourceFile4951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4952", + "filePath": "resourceFile4952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4953", + "filePath": "resourceFile4953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4954", + "filePath": "resourceFile4954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4955", + "filePath": "resourceFile4955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4956", + "filePath": "resourceFile4956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4957", + "filePath": "resourceFile4957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4958", + "filePath": "resourceFile4958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4959", + "filePath": "resourceFile4959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4960", + "filePath": "resourceFile4960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4961", + "filePath": "resourceFile4961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4962", + "filePath": "resourceFile4962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4963", + "filePath": "resourceFile4963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4964", + "filePath": "resourceFile4964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4965", + "filePath": "resourceFile4965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4966", + "filePath": "resourceFile4966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4967", + "filePath": "resourceFile4967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4968", + "filePath": "resourceFile4968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4969", + "filePath": "resourceFile4969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4970", + "filePath": "resourceFile4970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4971", + "filePath": "resourceFile4971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4972", + "filePath": "resourceFile4972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4973", + "filePath": "resourceFile4973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4974", + "filePath": "resourceFile4974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4975", + "filePath": "resourceFile4975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4976", + "filePath": "resourceFile4976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4977", + "filePath": "resourceFile4977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4978", + "filePath": "resourceFile4978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4979", + "filePath": "resourceFile4979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4980", + "filePath": "resourceFile4980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4981", + "filePath": "resourceFile4981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4982", + "filePath": "resourceFile4982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4983", + "filePath": "resourceFile4983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4984", + "filePath": "resourceFile4984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4985", + "filePath": "resourceFile4985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4986", + "filePath": "resourceFile4986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4987", + "filePath": "resourceFile4987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4988", + "filePath": "resourceFile4988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4989", + "filePath": "resourceFile4989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4990", + "filePath": "resourceFile4990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4991", + "filePath": "resourceFile4991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4992", + "filePath": "resourceFile4992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4993", + "filePath": "resourceFile4993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4994", + "filePath": "resourceFile4994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4995", + "filePath": "resourceFile4995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4996", + "filePath": "resourceFile4996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4997", + "filePath": "resourceFile4997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4998", + "filePath": "resourceFile4998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4999", + "filePath": "resourceFile4999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5000", + "filePath": "resourceFile5000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5001", + "filePath": "resourceFile5001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5002", + "filePath": "resourceFile5002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5003", + "filePath": "resourceFile5003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5004", + "filePath": "resourceFile5004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5005", + "filePath": "resourceFile5005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5006", + "filePath": "resourceFile5006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5007", + "filePath": "resourceFile5007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5008", + "filePath": "resourceFile5008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5009", + "filePath": "resourceFile5009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5010", + "filePath": "resourceFile5010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5011", + "filePath": "resourceFile5011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5012", + "filePath": "resourceFile5012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5013", + "filePath": "resourceFile5013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5014", + "filePath": "resourceFile5014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5015", + "filePath": "resourceFile5015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5016", + "filePath": "resourceFile5016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5017", + "filePath": "resourceFile5017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5018", + "filePath": "resourceFile5018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5019", + "filePath": "resourceFile5019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5020", + "filePath": "resourceFile5020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5021", + "filePath": "resourceFile5021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5022", + "filePath": "resourceFile5022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5023", + "filePath": "resourceFile5023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5024", + "filePath": "resourceFile5024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5025", + "filePath": "resourceFile5025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5026", + "filePath": "resourceFile5026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5027", + "filePath": "resourceFile5027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5028", + "filePath": "resourceFile5028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5029", + "filePath": "resourceFile5029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5030", + "filePath": "resourceFile5030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5031", + "filePath": "resourceFile5031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5032", + "filePath": "resourceFile5032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5033", + "filePath": "resourceFile5033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5034", + "filePath": "resourceFile5034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5035", + "filePath": "resourceFile5035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5036", + "filePath": "resourceFile5036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5037", + "filePath": "resourceFile5037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5038", + "filePath": "resourceFile5038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5039", + "filePath": "resourceFile5039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5040", + "filePath": "resourceFile5040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5041", + "filePath": "resourceFile5041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5042", + "filePath": "resourceFile5042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5043", + "filePath": "resourceFile5043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5044", + "filePath": "resourceFile5044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5045", + "filePath": "resourceFile5045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5046", + "filePath": "resourceFile5046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5047", + "filePath": "resourceFile5047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5048", + "filePath": "resourceFile5048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5049", + "filePath": "resourceFile5049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5050", + "filePath": "resourceFile5050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5051", + "filePath": "resourceFile5051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5052", + "filePath": "resourceFile5052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5053", + "filePath": "resourceFile5053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5054", + "filePath": "resourceFile5054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5055", + "filePath": "resourceFile5055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5056", + "filePath": "resourceFile5056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5057", + "filePath": "resourceFile5057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5058", + "filePath": "resourceFile5058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5059", + "filePath": "resourceFile5059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5060", + "filePath": "resourceFile5060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5061", + "filePath": "resourceFile5061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5062", + "filePath": "resourceFile5062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5063", + "filePath": "resourceFile5063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5064", + "filePath": "resourceFile5064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5065", + "filePath": "resourceFile5065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5066", + "filePath": "resourceFile5066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5067", + "filePath": "resourceFile5067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5068", + "filePath": "resourceFile5068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5069", + "filePath": "resourceFile5069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5070", + "filePath": "resourceFile5070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5071", + "filePath": "resourceFile5071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5072", + "filePath": "resourceFile5072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5073", + "filePath": "resourceFile5073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5074", + "filePath": "resourceFile5074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5075", + "filePath": "resourceFile5075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5076", + "filePath": "resourceFile5076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5077", + "filePath": "resourceFile5077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5078", + "filePath": "resourceFile5078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5079", + "filePath": "resourceFile5079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5080", + "filePath": "resourceFile5080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5081", + "filePath": "resourceFile5081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5082", + "filePath": "resourceFile5082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5083", + "filePath": "resourceFile5083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5084", + "filePath": "resourceFile5084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5085", + "filePath": "resourceFile5085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5086", + "filePath": "resourceFile5086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5087", + "filePath": "resourceFile5087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5088", + "filePath": "resourceFile5088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5089", + "filePath": "resourceFile5089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5090", + "filePath": "resourceFile5090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5091", + "filePath": "resourceFile5091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5092", + "filePath": "resourceFile5092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5093", + "filePath": "resourceFile5093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5094", + "filePath": "resourceFile5094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5095", + "filePath": "resourceFile5095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5096", + "filePath": "resourceFile5096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5097", + "filePath": "resourceFile5097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5098", + "filePath": "resourceFile5098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5099", + "filePath": "resourceFile5099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5100", + "filePath": "resourceFile5100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5101", + "filePath": "resourceFile5101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5102", + "filePath": "resourceFile5102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5103", + "filePath": "resourceFile5103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5104", + "filePath": "resourceFile5104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5105", + "filePath": "resourceFile5105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5106", + "filePath": "resourceFile5106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5107", + "filePath": "resourceFile5107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5108", + "filePath": "resourceFile5108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5109", + "filePath": "resourceFile5109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5110", + "filePath": "resourceFile5110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5111", + "filePath": "resourceFile5111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5112", + "filePath": "resourceFile5112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5113", + "filePath": "resourceFile5113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5114", + "filePath": "resourceFile5114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5115", + "filePath": "resourceFile5115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5116", + "filePath": "resourceFile5116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5117", + "filePath": "resourceFile5117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5118", + "filePath": "resourceFile5118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5119", + "filePath": "resourceFile5119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5120", + "filePath": "resourceFile5120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5121", + "filePath": "resourceFile5121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5122", + "filePath": "resourceFile5122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5123", + "filePath": "resourceFile5123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5124", + "filePath": "resourceFile5124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5125", + "filePath": "resourceFile5125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5126", + "filePath": "resourceFile5126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5127", + "filePath": "resourceFile5127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5128", + "filePath": "resourceFile5128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5129", + "filePath": "resourceFile5129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5130", + "filePath": "resourceFile5130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5131", + "filePath": "resourceFile5131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5132", + "filePath": "resourceFile5132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5133", + "filePath": "resourceFile5133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5134", + "filePath": "resourceFile5134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5135", + "filePath": "resourceFile5135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5136", + "filePath": "resourceFile5136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5137", + "filePath": "resourceFile5137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5138", + "filePath": "resourceFile5138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5139", + "filePath": "resourceFile5139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5140", + "filePath": "resourceFile5140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5141", + "filePath": "resourceFile5141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5142", + "filePath": "resourceFile5142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5143", + "filePath": "resourceFile5143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5144", + "filePath": "resourceFile5144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5145", + "filePath": "resourceFile5145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5146", + "filePath": "resourceFile5146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5147", + "filePath": "resourceFile5147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5148", + "filePath": "resourceFile5148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5149", + "filePath": "resourceFile5149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5150", + "filePath": "resourceFile5150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5151", + "filePath": "resourceFile5151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5152", + "filePath": "resourceFile5152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5153", + "filePath": "resourceFile5153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5154", + "filePath": "resourceFile5154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5155", + "filePath": "resourceFile5155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5156", + "filePath": "resourceFile5156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5157", + "filePath": "resourceFile5157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5158", + "filePath": "resourceFile5158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5159", + "filePath": "resourceFile5159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5160", + "filePath": "resourceFile5160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5161", + "filePath": "resourceFile5161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5162", + "filePath": "resourceFile5162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5163", + "filePath": "resourceFile5163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5164", + "filePath": "resourceFile5164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5165", + "filePath": "resourceFile5165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5166", + "filePath": "resourceFile5166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5167", + "filePath": "resourceFile5167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5168", + "filePath": "resourceFile5168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5169", + "filePath": "resourceFile5169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5170", + "filePath": "resourceFile5170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5171", + "filePath": "resourceFile5171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5172", + "filePath": "resourceFile5172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5173", + "filePath": "resourceFile5173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5174", + "filePath": "resourceFile5174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5175", + "filePath": "resourceFile5175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5176", + "filePath": "resourceFile5176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5177", + "filePath": "resourceFile5177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5178", + "filePath": "resourceFile5178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5179", + "filePath": "resourceFile5179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5180", + "filePath": "resourceFile5180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5181", + "filePath": "resourceFile5181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5182", + "filePath": "resourceFile5182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5183", + "filePath": "resourceFile5183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5184", + "filePath": "resourceFile5184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5185", + "filePath": "resourceFile5185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5186", + "filePath": "resourceFile5186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5187", + "filePath": "resourceFile5187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5188", + "filePath": "resourceFile5188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5189", + "filePath": "resourceFile5189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5190", + "filePath": "resourceFile5190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5191", + "filePath": "resourceFile5191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5192", + "filePath": "resourceFile5192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5193", + "filePath": "resourceFile5193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5194", + "filePath": "resourceFile5194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5195", + "filePath": "resourceFile5195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5196", + "filePath": "resourceFile5196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5197", + "filePath": "resourceFile5197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5198", + "filePath": "resourceFile5198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5199", + "filePath": "resourceFile5199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5200", + "filePath": "resourceFile5200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5201", + "filePath": "resourceFile5201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5202", + "filePath": "resourceFile5202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5203", + "filePath": "resourceFile5203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5204", + "filePath": "resourceFile5204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5205", + "filePath": "resourceFile5205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5206", + "filePath": "resourceFile5206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5207", + "filePath": "resourceFile5207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5208", + "filePath": "resourceFile5208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5209", + "filePath": "resourceFile5209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5210", + "filePath": "resourceFile5210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5211", + "filePath": "resourceFile5211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5212", + "filePath": "resourceFile5212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5213", + "filePath": "resourceFile5213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5214", + "filePath": "resourceFile5214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5215", + "filePath": "resourceFile5215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5216", + "filePath": "resourceFile5216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5217", + "filePath": "resourceFile5217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5218", + "filePath": "resourceFile5218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5219", + "filePath": "resourceFile5219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5220", + "filePath": "resourceFile5220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5221", + "filePath": "resourceFile5221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5222", + "filePath": "resourceFile5222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5223", + "filePath": "resourceFile5223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5224", + "filePath": "resourceFile5224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5225", + "filePath": "resourceFile5225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5226", + "filePath": "resourceFile5226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5227", + "filePath": "resourceFile5227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5228", + "filePath": "resourceFile5228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5229", + "filePath": "resourceFile5229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5230", + "filePath": "resourceFile5230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5231", + "filePath": "resourceFile5231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5232", + "filePath": "resourceFile5232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5233", + "filePath": "resourceFile5233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5234", + "filePath": "resourceFile5234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5235", + "filePath": "resourceFile5235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5236", + "filePath": "resourceFile5236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5237", + "filePath": "resourceFile5237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5238", + "filePath": "resourceFile5238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5239", + "filePath": "resourceFile5239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5240", + "filePath": "resourceFile5240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5241", + "filePath": "resourceFile5241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5242", + "filePath": "resourceFile5242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5243", + "filePath": "resourceFile5243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5244", + "filePath": "resourceFile5244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5245", + "filePath": "resourceFile5245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5246", + "filePath": "resourceFile5246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5247", + "filePath": "resourceFile5247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5248", + "filePath": "resourceFile5248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5249", + "filePath": "resourceFile5249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5250", + "filePath": "resourceFile5250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5251", + "filePath": "resourceFile5251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5252", + "filePath": "resourceFile5252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5253", + "filePath": "resourceFile5253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5254", + "filePath": "resourceFile5254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5255", + "filePath": "resourceFile5255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5256", + "filePath": "resourceFile5256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5257", + "filePath": "resourceFile5257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5258", + "filePath": "resourceFile5258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5259", + "filePath": "resourceFile5259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5260", + "filePath": "resourceFile5260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5261", + "filePath": "resourceFile5261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5262", + "filePath": "resourceFile5262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5263", + "filePath": "resourceFile5263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5264", + "filePath": "resourceFile5264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5265", + "filePath": "resourceFile5265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5266", + "filePath": "resourceFile5266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5267", + "filePath": "resourceFile5267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5268", + "filePath": "resourceFile5268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5269", + "filePath": "resourceFile5269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5270", + "filePath": "resourceFile5270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5271", + "filePath": "resourceFile5271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5272", + "filePath": "resourceFile5272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5273", + "filePath": "resourceFile5273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5274", + "filePath": "resourceFile5274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5275", + "filePath": "resourceFile5275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5276", + "filePath": "resourceFile5276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5277", + "filePath": "resourceFile5277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5278", + "filePath": "resourceFile5278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5279", + "filePath": "resourceFile5279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5280", + "filePath": "resourceFile5280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5281", + "filePath": "resourceFile5281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5282", + "filePath": "resourceFile5282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5283", + "filePath": "resourceFile5283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5284", + "filePath": "resourceFile5284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5285", + "filePath": "resourceFile5285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5286", + "filePath": "resourceFile5286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5287", + "filePath": "resourceFile5287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5288", + "filePath": "resourceFile5288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5289", + "filePath": "resourceFile5289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5290", + "filePath": "resourceFile5290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5291", + "filePath": "resourceFile5291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5292", + "filePath": "resourceFile5292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5293", + "filePath": "resourceFile5293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5294", + "filePath": "resourceFile5294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5295", + "filePath": "resourceFile5295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5296", + "filePath": "resourceFile5296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5297", + "filePath": "resourceFile5297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5298", + "filePath": "resourceFile5298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5299", + "filePath": "resourceFile5299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5300", + "filePath": "resourceFile5300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5301", + "filePath": "resourceFile5301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5302", + "filePath": "resourceFile5302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5303", + "filePath": "resourceFile5303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5304", + "filePath": "resourceFile5304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5305", + "filePath": "resourceFile5305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5306", + "filePath": "resourceFile5306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5307", + "filePath": "resourceFile5307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5308", + "filePath": "resourceFile5308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5309", + "filePath": "resourceFile5309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5310", + "filePath": "resourceFile5310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5311", + "filePath": "resourceFile5311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5312", + "filePath": "resourceFile5312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5313", + "filePath": "resourceFile5313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5314", + "filePath": "resourceFile5314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5315", + "filePath": "resourceFile5315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5316", + "filePath": "resourceFile5316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5317", + "filePath": "resourceFile5317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5318", + "filePath": "resourceFile5318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5319", + "filePath": "resourceFile5319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5320", + "filePath": "resourceFile5320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5321", + "filePath": "resourceFile5321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5322", + "filePath": "resourceFile5322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5323", + "filePath": "resourceFile5323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5324", + "filePath": "resourceFile5324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5325", + "filePath": "resourceFile5325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5326", + "filePath": "resourceFile5326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5327", + "filePath": "resourceFile5327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5328", + "filePath": "resourceFile5328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5329", + "filePath": "resourceFile5329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5330", + "filePath": "resourceFile5330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5331", + "filePath": "resourceFile5331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5332", + "filePath": "resourceFile5332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5333", + "filePath": "resourceFile5333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5334", + "filePath": "resourceFile5334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5335", + "filePath": "resourceFile5335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5336", + "filePath": "resourceFile5336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5337", + "filePath": "resourceFile5337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5338", + "filePath": "resourceFile5338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5339", + "filePath": "resourceFile5339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5340", + "filePath": "resourceFile5340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5341", + "filePath": "resourceFile5341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5342", + "filePath": "resourceFile5342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5343", + "filePath": "resourceFile5343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5344", + "filePath": "resourceFile5344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5345", + "filePath": "resourceFile5345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5346", + "filePath": "resourceFile5346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5347", + "filePath": "resourceFile5347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5348", + "filePath": "resourceFile5348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5349", + "filePath": "resourceFile5349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5350", + "filePath": "resourceFile5350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5351", + "filePath": "resourceFile5351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5352", + "filePath": "resourceFile5352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5353", + "filePath": "resourceFile5353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5354", + "filePath": "resourceFile5354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5355", + "filePath": "resourceFile5355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5356", + "filePath": "resourceFile5356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5357", + "filePath": "resourceFile5357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5358", + "filePath": "resourceFile5358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5359", + "filePath": "resourceFile5359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5360", + "filePath": "resourceFile5360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5361", + "filePath": "resourceFile5361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5362", + "filePath": "resourceFile5362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5363", + "filePath": "resourceFile5363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5364", + "filePath": "resourceFile5364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5365", + "filePath": "resourceFile5365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5366", + "filePath": "resourceFile5366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5367", + "filePath": "resourceFile5367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5368", + "filePath": "resourceFile5368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5369", + "filePath": "resourceFile5369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5370", + "filePath": "resourceFile5370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5371", + "filePath": "resourceFile5371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5372", + "filePath": "resourceFile5372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5373", + "filePath": "resourceFile5373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5374", + "filePath": "resourceFile5374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5375", + "filePath": "resourceFile5375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5376", + "filePath": "resourceFile5376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5377", + "filePath": "resourceFile5377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5378", + "filePath": "resourceFile5378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5379", + "filePath": "resourceFile5379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5380", + "filePath": "resourceFile5380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5381", + "filePath": "resourceFile5381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5382", + "filePath": "resourceFile5382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5383", + "filePath": "resourceFile5383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5384", + "filePath": "resourceFile5384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5385", + "filePath": "resourceFile5385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5386", + "filePath": "resourceFile5386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5387", + "filePath": "resourceFile5387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5388", + "filePath": "resourceFile5388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5389", + "filePath": "resourceFile5389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5390", + "filePath": "resourceFile5390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5391", + "filePath": "resourceFile5391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5392", + "filePath": "resourceFile5392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5393", + "filePath": "resourceFile5393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5394", + "filePath": "resourceFile5394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5395", + "filePath": "resourceFile5395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5396", + "filePath": "resourceFile5396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5397", + "filePath": "resourceFile5397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5398", + "filePath": "resourceFile5398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5399", + "filePath": "resourceFile5399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5400", + "filePath": "resourceFile5400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5401", + "filePath": "resourceFile5401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5402", + "filePath": "resourceFile5402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5403", + "filePath": "resourceFile5403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5404", + "filePath": "resourceFile5404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5405", + "filePath": "resourceFile5405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5406", + "filePath": "resourceFile5406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5407", + "filePath": "resourceFile5407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5408", + "filePath": "resourceFile5408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5409", + "filePath": "resourceFile5409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5410", + "filePath": "resourceFile5410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5411", + "filePath": "resourceFile5411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5412", + "filePath": "resourceFile5412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5413", + "filePath": "resourceFile5413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5414", + "filePath": "resourceFile5414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5415", + "filePath": "resourceFile5415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5416", + "filePath": "resourceFile5416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5417", + "filePath": "resourceFile5417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5418", + "filePath": "resourceFile5418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5419", + "filePath": "resourceFile5419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5420", + "filePath": "resourceFile5420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5421", + "filePath": "resourceFile5421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5422", + "filePath": "resourceFile5422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5423", + "filePath": "resourceFile5423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5424", + "filePath": "resourceFile5424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5425", + "filePath": "resourceFile5425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5426", + "filePath": "resourceFile5426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5427", + "filePath": "resourceFile5427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5428", + "filePath": "resourceFile5428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5429", + "filePath": "resourceFile5429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5430", + "filePath": "resourceFile5430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5431", + "filePath": "resourceFile5431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5432", + "filePath": "resourceFile5432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5433", + "filePath": "resourceFile5433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5434", + "filePath": "resourceFile5434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5435", + "filePath": "resourceFile5435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5436", + "filePath": "resourceFile5436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5437", + "filePath": "resourceFile5437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5438", + "filePath": "resourceFile5438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5439", + "filePath": "resourceFile5439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5440", + "filePath": "resourceFile5440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5441", + "filePath": "resourceFile5441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5442", + "filePath": "resourceFile5442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5443", + "filePath": "resourceFile5443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5444", + "filePath": "resourceFile5444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5445", + "filePath": "resourceFile5445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5446", + "filePath": "resourceFile5446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5447", + "filePath": "resourceFile5447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5448", + "filePath": "resourceFile5448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5449", + "filePath": "resourceFile5449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5450", + "filePath": "resourceFile5450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5451", + "filePath": "resourceFile5451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5452", + "filePath": "resourceFile5452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5453", + "filePath": "resourceFile5453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5454", + "filePath": "resourceFile5454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5455", + "filePath": "resourceFile5455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5456", + "filePath": "resourceFile5456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5457", + "filePath": "resourceFile5457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5458", + "filePath": "resourceFile5458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5459", + "filePath": "resourceFile5459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5460", + "filePath": "resourceFile5460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5461", + "filePath": "resourceFile5461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5462", + "filePath": "resourceFile5462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5463", + "filePath": "resourceFile5463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5464", + "filePath": "resourceFile5464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5465", + "filePath": "resourceFile5465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5466", + "filePath": "resourceFile5466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5467", + "filePath": "resourceFile5467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5468", + "filePath": "resourceFile5468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5469", + "filePath": "resourceFile5469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5470", + "filePath": "resourceFile5470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5471", + "filePath": "resourceFile5471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5472", + "filePath": "resourceFile5472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5473", + "filePath": "resourceFile5473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5474", + "filePath": "resourceFile5474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5475", + "filePath": "resourceFile5475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5476", + "filePath": "resourceFile5476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5477", + "filePath": "resourceFile5477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5478", + "filePath": "resourceFile5478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5479", + "filePath": "resourceFile5479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5480", + "filePath": "resourceFile5480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5481", + "filePath": "resourceFile5481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5482", + "filePath": "resourceFile5482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5483", + "filePath": "resourceFile5483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5484", + "filePath": "resourceFile5484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5485", + "filePath": "resourceFile5485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5486", + "filePath": "resourceFile5486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5487", + "filePath": "resourceFile5487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5488", + "filePath": "resourceFile5488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5489", + "filePath": "resourceFile5489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5490", + "filePath": "resourceFile5490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5491", + "filePath": "resourceFile5491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5492", + "filePath": "resourceFile5492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5493", + "filePath": "resourceFile5493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5494", + "filePath": "resourceFile5494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5495", + "filePath": "resourceFile5495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5496", + "filePath": "resourceFile5496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5497", + "filePath": "resourceFile5497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5498", + "filePath": "resourceFile5498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5499", + "filePath": "resourceFile5499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5500", + "filePath": "resourceFile5500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5501", + "filePath": "resourceFile5501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5502", + "filePath": "resourceFile5502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5503", + "filePath": "resourceFile5503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5504", + "filePath": "resourceFile5504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5505", + "filePath": "resourceFile5505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5506", + "filePath": "resourceFile5506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5507", + "filePath": "resourceFile5507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5508", + "filePath": "resourceFile5508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5509", + "filePath": "resourceFile5509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5510", + "filePath": "resourceFile5510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5511", + "filePath": "resourceFile5511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5512", + "filePath": "resourceFile5512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5513", + "filePath": "resourceFile5513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5514", + "filePath": "resourceFile5514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5515", + "filePath": "resourceFile5515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5516", + "filePath": "resourceFile5516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5517", + "filePath": "resourceFile5517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5518", + "filePath": "resourceFile5518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5519", + "filePath": "resourceFile5519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5520", + "filePath": "resourceFile5520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5521", + "filePath": "resourceFile5521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5522", + "filePath": "resourceFile5522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5523", + "filePath": "resourceFile5523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5524", + "filePath": "resourceFile5524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5525", + "filePath": "resourceFile5525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5526", + "filePath": "resourceFile5526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5527", + "filePath": "resourceFile5527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5528", + "filePath": "resourceFile5528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5529", + "filePath": "resourceFile5529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5530", + "filePath": "resourceFile5530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5531", + "filePath": "resourceFile5531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5532", + "filePath": "resourceFile5532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5533", + "filePath": "resourceFile5533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5534", + "filePath": "resourceFile5534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5535", + "filePath": "resourceFile5535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5536", + "filePath": "resourceFile5536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5537", + "filePath": "resourceFile5537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5538", + "filePath": "resourceFile5538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5539", + "filePath": "resourceFile5539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5540", + "filePath": "resourceFile5540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5541", + "filePath": "resourceFile5541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5542", + "filePath": "resourceFile5542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5543", + "filePath": "resourceFile5543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5544", + "filePath": "resourceFile5544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5545", + "filePath": "resourceFile5545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5546", + "filePath": "resourceFile5546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5547", + "filePath": "resourceFile5547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5548", + "filePath": "resourceFile5548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5549", + "filePath": "resourceFile5549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5550", + "filePath": "resourceFile5550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5551", + "filePath": "resourceFile5551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5552", + "filePath": "resourceFile5552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5553", + "filePath": "resourceFile5553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5554", + "filePath": "resourceFile5554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5555", + "filePath": "resourceFile5555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5556", + "filePath": "resourceFile5556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5557", + "filePath": "resourceFile5557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5558", + "filePath": "resourceFile5558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5559", + "filePath": "resourceFile5559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5560", + "filePath": "resourceFile5560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5561", + "filePath": "resourceFile5561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5562", + "filePath": "resourceFile5562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5563", + "filePath": "resourceFile5563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5564", + "filePath": "resourceFile5564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5565", + "filePath": "resourceFile5565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5566", + "filePath": "resourceFile5566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5567", + "filePath": "resourceFile5567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5568", + "filePath": "resourceFile5568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5569", + "filePath": "resourceFile5569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5570", + "filePath": "resourceFile5570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5571", + "filePath": "resourceFile5571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5572", + "filePath": "resourceFile5572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5573", + "filePath": "resourceFile5573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5574", + "filePath": "resourceFile5574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5575", + "filePath": "resourceFile5575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5576", + "filePath": "resourceFile5576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5577", + "filePath": "resourceFile5577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5578", + "filePath": "resourceFile5578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5579", + "filePath": "resourceFile5579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5580", + "filePath": "resourceFile5580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5581", + "filePath": "resourceFile5581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5582", + "filePath": "resourceFile5582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5583", + "filePath": "resourceFile5583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5584", + "filePath": "resourceFile5584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5585", + "filePath": "resourceFile5585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5586", + "filePath": "resourceFile5586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5587", + "filePath": "resourceFile5587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5588", + "filePath": "resourceFile5588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5589", + "filePath": "resourceFile5589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5590", + "filePath": "resourceFile5590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5591", + "filePath": "resourceFile5591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5592", + "filePath": "resourceFile5592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5593", + "filePath": "resourceFile5593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5594", + "filePath": "resourceFile5594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5595", + "filePath": "resourceFile5595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5596", + "filePath": "resourceFile5596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5597", + "filePath": "resourceFile5597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5598", + "filePath": "resourceFile5598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5599", + "filePath": "resourceFile5599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5600", + "filePath": "resourceFile5600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5601", + "filePath": "resourceFile5601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5602", + "filePath": "resourceFile5602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5603", + "filePath": "resourceFile5603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5604", + "filePath": "resourceFile5604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5605", + "filePath": "resourceFile5605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5606", + "filePath": "resourceFile5606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5607", + "filePath": "resourceFile5607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5608", + "filePath": "resourceFile5608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5609", + "filePath": "resourceFile5609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5610", + "filePath": "resourceFile5610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5611", + "filePath": "resourceFile5611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5612", + "filePath": "resourceFile5612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5613", + "filePath": "resourceFile5613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5614", + "filePath": "resourceFile5614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5615", + "filePath": "resourceFile5615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5616", + "filePath": "resourceFile5616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5617", + "filePath": "resourceFile5617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5618", + "filePath": "resourceFile5618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5619", + "filePath": "resourceFile5619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5620", + "filePath": "resourceFile5620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5621", + "filePath": "resourceFile5621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5622", + "filePath": "resourceFile5622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5623", + "filePath": "resourceFile5623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5624", + "filePath": "resourceFile5624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5625", + "filePath": "resourceFile5625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5626", + "filePath": "resourceFile5626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5627", + "filePath": "resourceFile5627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5628", + "filePath": "resourceFile5628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5629", + "filePath": "resourceFile5629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5630", + "filePath": "resourceFile5630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5631", + "filePath": "resourceFile5631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5632", + "filePath": "resourceFile5632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5633", + "filePath": "resourceFile5633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5634", + "filePath": "resourceFile5634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5635", + "filePath": "resourceFile5635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5636", + "filePath": "resourceFile5636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5637", + "filePath": "resourceFile5637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5638", + "filePath": "resourceFile5638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5639", + "filePath": "resourceFile5639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5640", + "filePath": "resourceFile5640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5641", + "filePath": "resourceFile5641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5642", + "filePath": "resourceFile5642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5643", + "filePath": "resourceFile5643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5644", + "filePath": "resourceFile5644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5645", + "filePath": "resourceFile5645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5646", + "filePath": "resourceFile5646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5647", + "filePath": "resourceFile5647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5648", + "filePath": "resourceFile5648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5649", + "filePath": "resourceFile5649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5650", + "filePath": "resourceFile5650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5651", + "filePath": "resourceFile5651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5652", + "filePath": "resourceFile5652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5653", + "filePath": "resourceFile5653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5654", + "filePath": "resourceFile5654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5655", + "filePath": "resourceFile5655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5656", + "filePath": "resourceFile5656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5657", + "filePath": "resourceFile5657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5658", + "filePath": "resourceFile5658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5659", + "filePath": "resourceFile5659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5660", + "filePath": "resourceFile5660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5661", + "filePath": "resourceFile5661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5662", + "filePath": "resourceFile5662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5663", + "filePath": "resourceFile5663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5664", + "filePath": "resourceFile5664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5665", + "filePath": "resourceFile5665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5666", + "filePath": "resourceFile5666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5667", + "filePath": "resourceFile5667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5668", + "filePath": "resourceFile5668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5669", + "filePath": "resourceFile5669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5670", + "filePath": "resourceFile5670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5671", + "filePath": "resourceFile5671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5672", + "filePath": "resourceFile5672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5673", + "filePath": "resourceFile5673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5674", + "filePath": "resourceFile5674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5675", + "filePath": "resourceFile5675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5676", + "filePath": "resourceFile5676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5677", + "filePath": "resourceFile5677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5678", + "filePath": "resourceFile5678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5679", + "filePath": "resourceFile5679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5680", + "filePath": "resourceFile5680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5681", + "filePath": "resourceFile5681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5682", + "filePath": "resourceFile5682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5683", + "filePath": "resourceFile5683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5684", + "filePath": "resourceFile5684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5685", + "filePath": "resourceFile5685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5686", + "filePath": "resourceFile5686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5687", + "filePath": "resourceFile5687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5688", + "filePath": "resourceFile5688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5689", + "filePath": "resourceFile5689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5690", + "filePath": "resourceFile5690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5691", + "filePath": "resourceFile5691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5692", + "filePath": "resourceFile5692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5693", + "filePath": "resourceFile5693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5694", + "filePath": "resourceFile5694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5695", + "filePath": "resourceFile5695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5696", + "filePath": "resourceFile5696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5697", + "filePath": "resourceFile5697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5698", + "filePath": "resourceFile5698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5699", + "filePath": "resourceFile5699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5700", + "filePath": "resourceFile5700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5701", + "filePath": "resourceFile5701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5702", + "filePath": "resourceFile5702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5703", + "filePath": "resourceFile5703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5704", + "filePath": "resourceFile5704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5705", + "filePath": "resourceFile5705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5706", + "filePath": "resourceFile5706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5707", + "filePath": "resourceFile5707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5708", + "filePath": "resourceFile5708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5709", + "filePath": "resourceFile5709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5710", + "filePath": "resourceFile5710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5711", + "filePath": "resourceFile5711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5712", + "filePath": "resourceFile5712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5713", + "filePath": "resourceFile5713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5714", + "filePath": "resourceFile5714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5715", + "filePath": "resourceFile5715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5716", + "filePath": "resourceFile5716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5717", + "filePath": "resourceFile5717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5718", + "filePath": "resourceFile5718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5719", + "filePath": "resourceFile5719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5720", + "filePath": "resourceFile5720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5721", + "filePath": "resourceFile5721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5722", + "filePath": "resourceFile5722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5723", + "filePath": "resourceFile5723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5724", + "filePath": "resourceFile5724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5725", + "filePath": "resourceFile5725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5726", + "filePath": "resourceFile5726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5727", + "filePath": "resourceFile5727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5728", + "filePath": "resourceFile5728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5729", + "filePath": "resourceFile5729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5730", + "filePath": "resourceFile5730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5731", + "filePath": "resourceFile5731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5732", + "filePath": "resourceFile5732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5733", + "filePath": "resourceFile5733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5734", + "filePath": "resourceFile5734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5735", + "filePath": "resourceFile5735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5736", + "filePath": "resourceFile5736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5737", + "filePath": "resourceFile5737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5738", + "filePath": "resourceFile5738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5739", + "filePath": "resourceFile5739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5740", + "filePath": "resourceFile5740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5741", + "filePath": "resourceFile5741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5742", + "filePath": "resourceFile5742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5743", + "filePath": "resourceFile5743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5744", + "filePath": "resourceFile5744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5745", + "filePath": "resourceFile5745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5746", + "filePath": "resourceFile5746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5747", + "filePath": "resourceFile5747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5748", + "filePath": "resourceFile5748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5749", + "filePath": "resourceFile5749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5750", + "filePath": "resourceFile5750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5751", + "filePath": "resourceFile5751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5752", + "filePath": "resourceFile5752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5753", + "filePath": "resourceFile5753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5754", + "filePath": "resourceFile5754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5755", + "filePath": "resourceFile5755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5756", + "filePath": "resourceFile5756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5757", + "filePath": "resourceFile5757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5758", + "filePath": "resourceFile5758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5759", + "filePath": "resourceFile5759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5760", + "filePath": "resourceFile5760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5761", + "filePath": "resourceFile5761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5762", + "filePath": "resourceFile5762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5763", + "filePath": "resourceFile5763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5764", + "filePath": "resourceFile5764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5765", + "filePath": "resourceFile5765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5766", + "filePath": "resourceFile5766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5767", + "filePath": "resourceFile5767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5768", + "filePath": "resourceFile5768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5769", + "filePath": "resourceFile5769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5770", + "filePath": "resourceFile5770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5771", + "filePath": "resourceFile5771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5772", + "filePath": "resourceFile5772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5773", + "filePath": "resourceFile5773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5774", + "filePath": "resourceFile5774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5775", + "filePath": "resourceFile5775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5776", + "filePath": "resourceFile5776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5777", + "filePath": "resourceFile5777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5778", + "filePath": "resourceFile5778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5779", + "filePath": "resourceFile5779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5780", + "filePath": "resourceFile5780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5781", + "filePath": "resourceFile5781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5782", + "filePath": "resourceFile5782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5783", + "filePath": "resourceFile5783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5784", + "filePath": "resourceFile5784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5785", + "filePath": "resourceFile5785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5786", + "filePath": "resourceFile5786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5787", + "filePath": "resourceFile5787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5788", + "filePath": "resourceFile5788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5789", + "filePath": "resourceFile5789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5790", + "filePath": "resourceFile5790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5791", + "filePath": "resourceFile5791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5792", + "filePath": "resourceFile5792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5793", + "filePath": "resourceFile5793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5794", + "filePath": "resourceFile5794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5795", + "filePath": "resourceFile5795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5796", + "filePath": "resourceFile5796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5797", + "filePath": "resourceFile5797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5798", + "filePath": "resourceFile5798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5799", + "filePath": "resourceFile5799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5800", + "filePath": "resourceFile5800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5801", + "filePath": "resourceFile5801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5802", + "filePath": "resourceFile5802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5803", + "filePath": "resourceFile5803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5804", + "filePath": "resourceFile5804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5805", + "filePath": "resourceFile5805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5806", + "filePath": "resourceFile5806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5807", + "filePath": "resourceFile5807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5808", + "filePath": "resourceFile5808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5809", + "filePath": "resourceFile5809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5810", + "filePath": "resourceFile5810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5811", + "filePath": "resourceFile5811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5812", + "filePath": "resourceFile5812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5813", + "filePath": "resourceFile5813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5814", + "filePath": "resourceFile5814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5815", + "filePath": "resourceFile5815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5816", + "filePath": "resourceFile5816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5817", + "filePath": "resourceFile5817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5818", + "filePath": "resourceFile5818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5819", + "filePath": "resourceFile5819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5820", + "filePath": "resourceFile5820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5821", + "filePath": "resourceFile5821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5822", + "filePath": "resourceFile5822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5823", + "filePath": "resourceFile5823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5824", + "filePath": "resourceFile5824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5825", + "filePath": "resourceFile5825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5826", + "filePath": "resourceFile5826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5827", + "filePath": "resourceFile5827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5828", + "filePath": "resourceFile5828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5829", + "filePath": "resourceFile5829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5830", + "filePath": "resourceFile5830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5831", + "filePath": "resourceFile5831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5832", + "filePath": "resourceFile5832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5833", + "filePath": "resourceFile5833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5834", + "filePath": "resourceFile5834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5835", + "filePath": "resourceFile5835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5836", + "filePath": "resourceFile5836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5837", + "filePath": "resourceFile5837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5838", + "filePath": "resourceFile5838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5839", + "filePath": "resourceFile5839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5840", + "filePath": "resourceFile5840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5841", + "filePath": "resourceFile5841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5842", + "filePath": "resourceFile5842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5843", + "filePath": "resourceFile5843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5844", + "filePath": "resourceFile5844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5845", + "filePath": "resourceFile5845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5846", + "filePath": "resourceFile5846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5847", + "filePath": "resourceFile5847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5848", + "filePath": "resourceFile5848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5849", + "filePath": "resourceFile5849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5850", + "filePath": "resourceFile5850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5851", + "filePath": "resourceFile5851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5852", + "filePath": "resourceFile5852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5853", + "filePath": "resourceFile5853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5854", + "filePath": "resourceFile5854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5855", + "filePath": "resourceFile5855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5856", + "filePath": "resourceFile5856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5857", + "filePath": "resourceFile5857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5858", + "filePath": "resourceFile5858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5859", + "filePath": "resourceFile5859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5860", + "filePath": "resourceFile5860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5861", + "filePath": "resourceFile5861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5862", + "filePath": "resourceFile5862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5863", + "filePath": "resourceFile5863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5864", + "filePath": "resourceFile5864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5865", + "filePath": "resourceFile5865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5866", + "filePath": "resourceFile5866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5867", + "filePath": "resourceFile5867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5868", + "filePath": "resourceFile5868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5869", + "filePath": "resourceFile5869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5870", + "filePath": "resourceFile5870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5871", + "filePath": "resourceFile5871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5872", + "filePath": "resourceFile5872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5873", + "filePath": "resourceFile5873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5874", + "filePath": "resourceFile5874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5875", + "filePath": "resourceFile5875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5876", + "filePath": "resourceFile5876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5877", + "filePath": "resourceFile5877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5878", + "filePath": "resourceFile5878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5879", + "filePath": "resourceFile5879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5880", + "filePath": "resourceFile5880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5881", + "filePath": "resourceFile5881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5882", + "filePath": "resourceFile5882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5883", + "filePath": "resourceFile5883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5884", + "filePath": "resourceFile5884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5885", + "filePath": "resourceFile5885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5886", + "filePath": "resourceFile5886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5887", + "filePath": "resourceFile5887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5888", + "filePath": "resourceFile5888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5889", + "filePath": "resourceFile5889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5890", + "filePath": "resourceFile5890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5891", + "filePath": "resourceFile5891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5892", + "filePath": "resourceFile5892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5893", + "filePath": "resourceFile5893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5894", + "filePath": "resourceFile5894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5895", + "filePath": "resourceFile5895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5896", + "filePath": "resourceFile5896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5897", + "filePath": "resourceFile5897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5898", + "filePath": "resourceFile5898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5899", + "filePath": "resourceFile5899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5900", + "filePath": "resourceFile5900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5901", + "filePath": "resourceFile5901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5902", + "filePath": "resourceFile5902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5903", + "filePath": "resourceFile5903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5904", + "filePath": "resourceFile5904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5905", + "filePath": "resourceFile5905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5906", + "filePath": "resourceFile5906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5907", + "filePath": "resourceFile5907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5908", + "filePath": "resourceFile5908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5909", + "filePath": "resourceFile5909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5910", + "filePath": "resourceFile5910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5911", + "filePath": "resourceFile5911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5912", + "filePath": "resourceFile5912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5913", + "filePath": "resourceFile5913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5914", + "filePath": "resourceFile5914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5915", + "filePath": "resourceFile5915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5916", + "filePath": "resourceFile5916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5917", + "filePath": "resourceFile5917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5918", + "filePath": "resourceFile5918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5919", + "filePath": "resourceFile5919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5920", + "filePath": "resourceFile5920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5921", + "filePath": "resourceFile5921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5922", + "filePath": "resourceFile5922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5923", + "filePath": "resourceFile5923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5924", + "filePath": "resourceFile5924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5925", + "filePath": "resourceFile5925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5926", + "filePath": "resourceFile5926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5927", + "filePath": "resourceFile5927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5928", + "filePath": "resourceFile5928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5929", + "filePath": "resourceFile5929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5930", + "filePath": "resourceFile5930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5931", + "filePath": "resourceFile5931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5932", + "filePath": "resourceFile5932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5933", + "filePath": "resourceFile5933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5934", + "filePath": "resourceFile5934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5935", + "filePath": "resourceFile5935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5936", + "filePath": "resourceFile5936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5937", + "filePath": "resourceFile5937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5938", + "filePath": "resourceFile5938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5939", + "filePath": "resourceFile5939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5940", + "filePath": "resourceFile5940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5941", + "filePath": "resourceFile5941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5942", + "filePath": "resourceFile5942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5943", + "filePath": "resourceFile5943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5944", + "filePath": "resourceFile5944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5945", + "filePath": "resourceFile5945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5946", + "filePath": "resourceFile5946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5947", + "filePath": "resourceFile5947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5948", + "filePath": "resourceFile5948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5949", + "filePath": "resourceFile5949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5950", + "filePath": "resourceFile5950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5951", + "filePath": "resourceFile5951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5952", + "filePath": "resourceFile5952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5953", + "filePath": "resourceFile5953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5954", + "filePath": "resourceFile5954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5955", + "filePath": "resourceFile5955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5956", + "filePath": "resourceFile5956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5957", + "filePath": "resourceFile5957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5958", + "filePath": "resourceFile5958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5959", + "filePath": "resourceFile5959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5960", + "filePath": "resourceFile5960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5961", + "filePath": "resourceFile5961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5962", + "filePath": "resourceFile5962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5963", + "filePath": "resourceFile5963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5964", + "filePath": "resourceFile5964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5965", + "filePath": "resourceFile5965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5966", + "filePath": "resourceFile5966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5967", + "filePath": "resourceFile5967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5968", + "filePath": "resourceFile5968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5969", + "filePath": "resourceFile5969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5970", + "filePath": "resourceFile5970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5971", + "filePath": "resourceFile5971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5972", + "filePath": "resourceFile5972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5973", + "filePath": "resourceFile5973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5974", + "filePath": "resourceFile5974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5975", + "filePath": "resourceFile5975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5976", + "filePath": "resourceFile5976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5977", + "filePath": "resourceFile5977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5978", + "filePath": "resourceFile5978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5979", + "filePath": "resourceFile5979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5980", + "filePath": "resourceFile5980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5981", + "filePath": "resourceFile5981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5982", + "filePath": "resourceFile5982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5983", + "filePath": "resourceFile5983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5984", + "filePath": "resourceFile5984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5985", + "filePath": "resourceFile5985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5986", + "filePath": "resourceFile5986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5987", + "filePath": "resourceFile5987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5988", + "filePath": "resourceFile5988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5989", + "filePath": "resourceFile5989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5990", + "filePath": "resourceFile5990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5991", + "filePath": "resourceFile5991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5992", + "filePath": "resourceFile5992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5993", + "filePath": "resourceFile5993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5994", + "filePath": "resourceFile5994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5995", + "filePath": "resourceFile5995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5996", + "filePath": "resourceFile5996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5997", + "filePath": "resourceFile5997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5998", + "filePath": "resourceFile5998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5999", + "filePath": "resourceFile5999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6000", + "filePath": "resourceFile6000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6001", + "filePath": "resourceFile6001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6002", + "filePath": "resourceFile6002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6003", + "filePath": "resourceFile6003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6004", + "filePath": "resourceFile6004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6005", + "filePath": "resourceFile6005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6006", + "filePath": "resourceFile6006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6007", + "filePath": "resourceFile6007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6008", + "filePath": "resourceFile6008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6009", + "filePath": "resourceFile6009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6010", + "filePath": "resourceFile6010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6011", + "filePath": "resourceFile6011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6012", + "filePath": "resourceFile6012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6013", + "filePath": "resourceFile6013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6014", + "filePath": "resourceFile6014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6015", + "filePath": "resourceFile6015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6016", + "filePath": "resourceFile6016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6017", + "filePath": "resourceFile6017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6018", + "filePath": "resourceFile6018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6019", + "filePath": "resourceFile6019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6020", + "filePath": "resourceFile6020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6021", + "filePath": "resourceFile6021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6022", + "filePath": "resourceFile6022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6023", + "filePath": "resourceFile6023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6024", + "filePath": "resourceFile6024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6025", + "filePath": "resourceFile6025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6026", + "filePath": "resourceFile6026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6027", + "filePath": "resourceFile6027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6028", + "filePath": "resourceFile6028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6029", + "filePath": "resourceFile6029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6030", + "filePath": "resourceFile6030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6031", + "filePath": "resourceFile6031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6032", + "filePath": "resourceFile6032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6033", + "filePath": "resourceFile6033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6034", + "filePath": "resourceFile6034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6035", + "filePath": "resourceFile6035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6036", + "filePath": "resourceFile6036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6037", + "filePath": "resourceFile6037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6038", + "filePath": "resourceFile6038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6039", + "filePath": "resourceFile6039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6040", + "filePath": "resourceFile6040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6041", + "filePath": "resourceFile6041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6042", + "filePath": "resourceFile6042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6043", + "filePath": "resourceFile6043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6044", + "filePath": "resourceFile6044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6045", + "filePath": "resourceFile6045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6046", + "filePath": "resourceFile6046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6047", + "filePath": "resourceFile6047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6048", + "filePath": "resourceFile6048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6049", + "filePath": "resourceFile6049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6050", + "filePath": "resourceFile6050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6051", + "filePath": "resourceFile6051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6052", + "filePath": "resourceFile6052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6053", + "filePath": "resourceFile6053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6054", + "filePath": "resourceFile6054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6055", + "filePath": "resourceFile6055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6056", + "filePath": "resourceFile6056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6057", + "filePath": "resourceFile6057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6058", + "filePath": "resourceFile6058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6059", + "filePath": "resourceFile6059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6060", + "filePath": "resourceFile6060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6061", + "filePath": "resourceFile6061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6062", + "filePath": "resourceFile6062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6063", + "filePath": "resourceFile6063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6064", + "filePath": "resourceFile6064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6065", + "filePath": "resourceFile6065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6066", + "filePath": "resourceFile6066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6067", + "filePath": "resourceFile6067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6068", + "filePath": "resourceFile6068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6069", + "filePath": "resourceFile6069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6070", + "filePath": "resourceFile6070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6071", + "filePath": "resourceFile6071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6072", + "filePath": "resourceFile6072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6073", + "filePath": "resourceFile6073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6074", + "filePath": "resourceFile6074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6075", + "filePath": "resourceFile6075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6076", + "filePath": "resourceFile6076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6077", + "filePath": "resourceFile6077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6078", + "filePath": "resourceFile6078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6079", + "filePath": "resourceFile6079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6080", + "filePath": "resourceFile6080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6081", + "filePath": "resourceFile6081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6082", + "filePath": "resourceFile6082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6083", + "filePath": "resourceFile6083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6084", + "filePath": "resourceFile6084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6085", + "filePath": "resourceFile6085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6086", + "filePath": "resourceFile6086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6087", + "filePath": "resourceFile6087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6088", + "filePath": "resourceFile6088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6089", + "filePath": "resourceFile6089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6090", + "filePath": "resourceFile6090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6091", + "filePath": "resourceFile6091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6092", + "filePath": "resourceFile6092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6093", + "filePath": "resourceFile6093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6094", + "filePath": "resourceFile6094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6095", + "filePath": "resourceFile6095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6096", + "filePath": "resourceFile6096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6097", + "filePath": "resourceFile6097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6098", + "filePath": "resourceFile6098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6099", + "filePath": "resourceFile6099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6100", + "filePath": "resourceFile6100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6101", + "filePath": "resourceFile6101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6102", + "filePath": "resourceFile6102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6103", + "filePath": "resourceFile6103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6104", + "filePath": "resourceFile6104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6105", + "filePath": "resourceFile6105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6106", + "filePath": "resourceFile6106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6107", + "filePath": "resourceFile6107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6108", + "filePath": "resourceFile6108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6109", + "filePath": "resourceFile6109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6110", + "filePath": "resourceFile6110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6111", + "filePath": "resourceFile6111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6112", + "filePath": "resourceFile6112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6113", + "filePath": "resourceFile6113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6114", + "filePath": "resourceFile6114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6115", + "filePath": "resourceFile6115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6116", + "filePath": "resourceFile6116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6117", + "filePath": "resourceFile6117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6118", + "filePath": "resourceFile6118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6119", + "filePath": "resourceFile6119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6120", + "filePath": "resourceFile6120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6121", + "filePath": "resourceFile6121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6122", + "filePath": "resourceFile6122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6123", + "filePath": "resourceFile6123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6124", + "filePath": "resourceFile6124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6125", + "filePath": "resourceFile6125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6126", + "filePath": "resourceFile6126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6127", + "filePath": "resourceFile6127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6128", + "filePath": "resourceFile6128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6129", + "filePath": "resourceFile6129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6130", + "filePath": "resourceFile6130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6131", + "filePath": "resourceFile6131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6132", + "filePath": "resourceFile6132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6133", + "filePath": "resourceFile6133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6134", + "filePath": "resourceFile6134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6135", + "filePath": "resourceFile6135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6136", + "filePath": "resourceFile6136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6137", + "filePath": "resourceFile6137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6138", + "filePath": "resourceFile6138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6139", + "filePath": "resourceFile6139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6140", + "filePath": "resourceFile6140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6141", + "filePath": "resourceFile6141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6142", + "filePath": "resourceFile6142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6143", + "filePath": "resourceFile6143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6144", + "filePath": "resourceFile6144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6145", + "filePath": "resourceFile6145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6146", + "filePath": "resourceFile6146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6147", + "filePath": "resourceFile6147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6148", + "filePath": "resourceFile6148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6149", + "filePath": "resourceFile6149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6150", + "filePath": "resourceFile6150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6151", + "filePath": "resourceFile6151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6152", + "filePath": "resourceFile6152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6153", + "filePath": "resourceFile6153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6154", + "filePath": "resourceFile6154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6155", + "filePath": "resourceFile6155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6156", + "filePath": "resourceFile6156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6157", + "filePath": "resourceFile6157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6158", + "filePath": "resourceFile6158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6159", + "filePath": "resourceFile6159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6160", + "filePath": "resourceFile6160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6161", + "filePath": "resourceFile6161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6162", + "filePath": "resourceFile6162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6163", + "filePath": "resourceFile6163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6164", + "filePath": "resourceFile6164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6165", + "filePath": "resourceFile6165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6166", + "filePath": "resourceFile6166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6167", + "filePath": "resourceFile6167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6168", + "filePath": "resourceFile6168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6169", + "filePath": "resourceFile6169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6170", + "filePath": "resourceFile6170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6171", + "filePath": "resourceFile6171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6172", + "filePath": "resourceFile6172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6173", + "filePath": "resourceFile6173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6174", + "filePath": "resourceFile6174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6175", + "filePath": "resourceFile6175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6176", + "filePath": "resourceFile6176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6177", + "filePath": "resourceFile6177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6178", + "filePath": "resourceFile6178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6179", + "filePath": "resourceFile6179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6180", + "filePath": "resourceFile6180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6181", + "filePath": "resourceFile6181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6182", + "filePath": "resourceFile6182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6183", + "filePath": "resourceFile6183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6184", + "filePath": "resourceFile6184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6185", + "filePath": "resourceFile6185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6186", + "filePath": "resourceFile6186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6187", + "filePath": "resourceFile6187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6188", + "filePath": "resourceFile6188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6189", + "filePath": "resourceFile6189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6190", + "filePath": "resourceFile6190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6191", + "filePath": "resourceFile6191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6192", + "filePath": "resourceFile6192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6193", + "filePath": "resourceFile6193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6194", + "filePath": "resourceFile6194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6195", + "filePath": "resourceFile6195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6196", + "filePath": "resourceFile6196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6197", + "filePath": "resourceFile6197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6198", + "filePath": "resourceFile6198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6199", + "filePath": "resourceFile6199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6200", + "filePath": "resourceFile6200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6201", + "filePath": "resourceFile6201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6202", + "filePath": "resourceFile6202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6203", + "filePath": "resourceFile6203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6204", + "filePath": "resourceFile6204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6205", + "filePath": "resourceFile6205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6206", + "filePath": "resourceFile6206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6207", + "filePath": "resourceFile6207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6208", + "filePath": "resourceFile6208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6209", + "filePath": "resourceFile6209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6210", + "filePath": "resourceFile6210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6211", + "filePath": "resourceFile6211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6212", + "filePath": "resourceFile6212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6213", + "filePath": "resourceFile6213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6214", + "filePath": "resourceFile6214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6215", + "filePath": "resourceFile6215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6216", + "filePath": "resourceFile6216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6217", + "filePath": "resourceFile6217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6218", + "filePath": "resourceFile6218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6219", + "filePath": "resourceFile6219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6220", + "filePath": "resourceFile6220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6221", + "filePath": "resourceFile6221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6222", + "filePath": "resourceFile6222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6223", + "filePath": "resourceFile6223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6224", + "filePath": "resourceFile6224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6225", + "filePath": "resourceFile6225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6226", + "filePath": "resourceFile6226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6227", + "filePath": "resourceFile6227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6228", + "filePath": "resourceFile6228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6229", + "filePath": "resourceFile6229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6230", + "filePath": "resourceFile6230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6231", + "filePath": "resourceFile6231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6232", + "filePath": "resourceFile6232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6233", + "filePath": "resourceFile6233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6234", + "filePath": "resourceFile6234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6235", + "filePath": "resourceFile6235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6236", + "filePath": "resourceFile6236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6237", + "filePath": "resourceFile6237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6238", + "filePath": "resourceFile6238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6239", + "filePath": "resourceFile6239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6240", + "filePath": "resourceFile6240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6241", + "filePath": "resourceFile6241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6242", + "filePath": "resourceFile6242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6243", + "filePath": "resourceFile6243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6244", + "filePath": "resourceFile6244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6245", + "filePath": "resourceFile6245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6246", + "filePath": "resourceFile6246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6247", + "filePath": "resourceFile6247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6248", + "filePath": "resourceFile6248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6249", + "filePath": "resourceFile6249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6250", + "filePath": "resourceFile6250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6251", + "filePath": "resourceFile6251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6252", + "filePath": "resourceFile6252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6253", + "filePath": "resourceFile6253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6254", + "filePath": "resourceFile6254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6255", + "filePath": "resourceFile6255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6256", + "filePath": "resourceFile6256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6257", + "filePath": "resourceFile6257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6258", + "filePath": "resourceFile6258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6259", + "filePath": "resourceFile6259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6260", + "filePath": "resourceFile6260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6261", + "filePath": "resourceFile6261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6262", + "filePath": "resourceFile6262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6263", + "filePath": "resourceFile6263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6264", + "filePath": "resourceFile6264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6265", + "filePath": "resourceFile6265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6266", + "filePath": "resourceFile6266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6267", + "filePath": "resourceFile6267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6268", + "filePath": "resourceFile6268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6269", + "filePath": "resourceFile6269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6270", + "filePath": "resourceFile6270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6271", + "filePath": "resourceFile6271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6272", + "filePath": "resourceFile6272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6273", + "filePath": "resourceFile6273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6274", + "filePath": "resourceFile6274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6275", + "filePath": "resourceFile6275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6276", + "filePath": "resourceFile6276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6277", + "filePath": "resourceFile6277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6278", + "filePath": "resourceFile6278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6279", + "filePath": "resourceFile6279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6280", + "filePath": "resourceFile6280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6281", + "filePath": "resourceFile6281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6282", + "filePath": "resourceFile6282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6283", + "filePath": "resourceFile6283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6284", + "filePath": "resourceFile6284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6285", + "filePath": "resourceFile6285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6286", + "filePath": "resourceFile6286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6287", + "filePath": "resourceFile6287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6288", + "filePath": "resourceFile6288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6289", + "filePath": "resourceFile6289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6290", + "filePath": "resourceFile6290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6291", + "filePath": "resourceFile6291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6292", + "filePath": "resourceFile6292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6293", + "filePath": "resourceFile6293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6294", + "filePath": "resourceFile6294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6295", + "filePath": "resourceFile6295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6296", + "filePath": "resourceFile6296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6297", + "filePath": "resourceFile6297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6298", + "filePath": "resourceFile6298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6299", + "filePath": "resourceFile6299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6300", + "filePath": "resourceFile6300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6301", + "filePath": "resourceFile6301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6302", + "filePath": "resourceFile6302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6303", + "filePath": "resourceFile6303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6304", + "filePath": "resourceFile6304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6305", + "filePath": "resourceFile6305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6306", + "filePath": "resourceFile6306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6307", + "filePath": "resourceFile6307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6308", + "filePath": "resourceFile6308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6309", + "filePath": "resourceFile6309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6310", + "filePath": "resourceFile6310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6311", + "filePath": "resourceFile6311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6312", + "filePath": "resourceFile6312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6313", + "filePath": "resourceFile6313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6314", + "filePath": "resourceFile6314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6315", + "filePath": "resourceFile6315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6316", + "filePath": "resourceFile6316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6317", + "filePath": "resourceFile6317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6318", + "filePath": "resourceFile6318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6319", + "filePath": "resourceFile6319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6320", + "filePath": "resourceFile6320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6321", + "filePath": "resourceFile6321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6322", + "filePath": "resourceFile6322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6323", + "filePath": "resourceFile6323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6324", + "filePath": "resourceFile6324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6325", + "filePath": "resourceFile6325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6326", + "filePath": "resourceFile6326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6327", + "filePath": "resourceFile6327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6328", + "filePath": "resourceFile6328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6329", + "filePath": "resourceFile6329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6330", + "filePath": "resourceFile6330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6331", + "filePath": "resourceFile6331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6332", + "filePath": "resourceFile6332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6333", + "filePath": "resourceFile6333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6334", + "filePath": "resourceFile6334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6335", + "filePath": "resourceFile6335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6336", + "filePath": "resourceFile6336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6337", + "filePath": "resourceFile6337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6338", + "filePath": "resourceFile6338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6339", + "filePath": "resourceFile6339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6340", + "filePath": "resourceFile6340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6341", + "filePath": "resourceFile6341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6342", + "filePath": "resourceFile6342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6343", + "filePath": "resourceFile6343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6344", + "filePath": "resourceFile6344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6345", + "filePath": "resourceFile6345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6346", + "filePath": "resourceFile6346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6347", + "filePath": "resourceFile6347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6348", + "filePath": "resourceFile6348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6349", + "filePath": "resourceFile6349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6350", + "filePath": "resourceFile6350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6351", + "filePath": "resourceFile6351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6352", + "filePath": "resourceFile6352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6353", + "filePath": "resourceFile6353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6354", + "filePath": "resourceFile6354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6355", + "filePath": "resourceFile6355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6356", + "filePath": "resourceFile6356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6357", + "filePath": "resourceFile6357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6358", + "filePath": "resourceFile6358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6359", + "filePath": "resourceFile6359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6360", + "filePath": "resourceFile6360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6361", + "filePath": "resourceFile6361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6362", + "filePath": "resourceFile6362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6363", + "filePath": "resourceFile6363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6364", + "filePath": "resourceFile6364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6365", + "filePath": "resourceFile6365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6366", + "filePath": "resourceFile6366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6367", + "filePath": "resourceFile6367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6368", + "filePath": "resourceFile6368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6369", + "filePath": "resourceFile6369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6370", + "filePath": "resourceFile6370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6371", + "filePath": "resourceFile6371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6372", + "filePath": "resourceFile6372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6373", + "filePath": "resourceFile6373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6374", + "filePath": "resourceFile6374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6375", + "filePath": "resourceFile6375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6376", + "filePath": "resourceFile6376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6377", + "filePath": "resourceFile6377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6378", + "filePath": "resourceFile6378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6379", + "filePath": "resourceFile6379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6380", + "filePath": "resourceFile6380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6381", + "filePath": "resourceFile6381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6382", + "filePath": "resourceFile6382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6383", + "filePath": "resourceFile6383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6384", + "filePath": "resourceFile6384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6385", + "filePath": "resourceFile6385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6386", + "filePath": "resourceFile6386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6387", + "filePath": "resourceFile6387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6388", + "filePath": "resourceFile6388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6389", + "filePath": "resourceFile6389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6390", + "filePath": "resourceFile6390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6391", + "filePath": "resourceFile6391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6392", + "filePath": "resourceFile6392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6393", + "filePath": "resourceFile6393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6394", + "filePath": "resourceFile6394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6395", + "filePath": "resourceFile6395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6396", + "filePath": "resourceFile6396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6397", + "filePath": "resourceFile6397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6398", + "filePath": "resourceFile6398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6399", + "filePath": "resourceFile6399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6400", + "filePath": "resourceFile6400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6401", + "filePath": "resourceFile6401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6402", + "filePath": "resourceFile6402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6403", + "filePath": "resourceFile6403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6404", + "filePath": "resourceFile6404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6405", + "filePath": "resourceFile6405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6406", + "filePath": "resourceFile6406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6407", + "filePath": "resourceFile6407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6408", + "filePath": "resourceFile6408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6409", + "filePath": "resourceFile6409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6410", + "filePath": "resourceFile6410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6411", + "filePath": "resourceFile6411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6412", + "filePath": "resourceFile6412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6413", + "filePath": "resourceFile6413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6414", + "filePath": "resourceFile6414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6415", + "filePath": "resourceFile6415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6416", + "filePath": "resourceFile6416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6417", + "filePath": "resourceFile6417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6418", + "filePath": "resourceFile6418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6419", + "filePath": "resourceFile6419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6420", + "filePath": "resourceFile6420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6421", + "filePath": "resourceFile6421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6422", + "filePath": "resourceFile6422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6423", + "filePath": "resourceFile6423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6424", + "filePath": "resourceFile6424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6425", + "filePath": "resourceFile6425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6426", + "filePath": "resourceFile6426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6427", + "filePath": "resourceFile6427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6428", + "filePath": "resourceFile6428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6429", + "filePath": "resourceFile6429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6430", + "filePath": "resourceFile6430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6431", + "filePath": "resourceFile6431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6432", + "filePath": "resourceFile6432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6433", + "filePath": "resourceFile6433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6434", + "filePath": "resourceFile6434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6435", + "filePath": "resourceFile6435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6436", + "filePath": "resourceFile6436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6437", + "filePath": "resourceFile6437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6438", + "filePath": "resourceFile6438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6439", + "filePath": "resourceFile6439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6440", + "filePath": "resourceFile6440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6441", + "filePath": "resourceFile6441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6442", + "filePath": "resourceFile6442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6443", + "filePath": "resourceFile6443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6444", + "filePath": "resourceFile6444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6445", + "filePath": "resourceFile6445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6446", + "filePath": "resourceFile6446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6447", + "filePath": "resourceFile6447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6448", + "filePath": "resourceFile6448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6449", + "filePath": "resourceFile6449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6450", + "filePath": "resourceFile6450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6451", + "filePath": "resourceFile6451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6452", + "filePath": "resourceFile6452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6453", + "filePath": "resourceFile6453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6454", + "filePath": "resourceFile6454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6455", + "filePath": "resourceFile6455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6456", + "filePath": "resourceFile6456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6457", + "filePath": "resourceFile6457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6458", + "filePath": "resourceFile6458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6459", + "filePath": "resourceFile6459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6460", + "filePath": "resourceFile6460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6461", + "filePath": "resourceFile6461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6462", + "filePath": "resourceFile6462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6463", + "filePath": "resourceFile6463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6464", + "filePath": "resourceFile6464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6465", + "filePath": "resourceFile6465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6466", + "filePath": "resourceFile6466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6467", + "filePath": "resourceFile6467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6468", + "filePath": "resourceFile6468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6469", + "filePath": "resourceFile6469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6470", + "filePath": "resourceFile6470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6471", + "filePath": "resourceFile6471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6472", + "filePath": "resourceFile6472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6473", + "filePath": "resourceFile6473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6474", + "filePath": "resourceFile6474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6475", + "filePath": "resourceFile6475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6476", + "filePath": "resourceFile6476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6477", + "filePath": "resourceFile6477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6478", + "filePath": "resourceFile6478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6479", + "filePath": "resourceFile6479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6480", + "filePath": "resourceFile6480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6481", + "filePath": "resourceFile6481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6482", + "filePath": "resourceFile6482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6483", + "filePath": "resourceFile6483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6484", + "filePath": "resourceFile6484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6485", + "filePath": "resourceFile6485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6486", + "filePath": "resourceFile6486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6487", + "filePath": "resourceFile6487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6488", + "filePath": "resourceFile6488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6489", + "filePath": "resourceFile6489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6490", + "filePath": "resourceFile6490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6491", + "filePath": "resourceFile6491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6492", + "filePath": "resourceFile6492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6493", + "filePath": "resourceFile6493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6494", + "filePath": "resourceFile6494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6495", + "filePath": "resourceFile6495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6496", + "filePath": "resourceFile6496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6497", + "filePath": "resourceFile6497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6498", + "filePath": "resourceFile6498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6499", + "filePath": "resourceFile6499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6500", + "filePath": "resourceFile6500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6501", + "filePath": "resourceFile6501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6502", + "filePath": "resourceFile6502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6503", + "filePath": "resourceFile6503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6504", + "filePath": "resourceFile6504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6505", + "filePath": "resourceFile6505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6506", + "filePath": "resourceFile6506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6507", + "filePath": "resourceFile6507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6508", + "filePath": "resourceFile6508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6509", + "filePath": "resourceFile6509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6510", + "filePath": "resourceFile6510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6511", + "filePath": "resourceFile6511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6512", + "filePath": "resourceFile6512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6513", + "filePath": "resourceFile6513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6514", + "filePath": "resourceFile6514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6515", + "filePath": "resourceFile6515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6516", + "filePath": "resourceFile6516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6517", + "filePath": "resourceFile6517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6518", + "filePath": "resourceFile6518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6519", + "filePath": "resourceFile6519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6520", + "filePath": "resourceFile6520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6521", + "filePath": "resourceFile6521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6522", + "filePath": "resourceFile6522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6523", + "filePath": "resourceFile6523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6524", + "filePath": "resourceFile6524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6525", + "filePath": "resourceFile6525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6526", + "filePath": "resourceFile6526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6527", + "filePath": "resourceFile6527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6528", + "filePath": "resourceFile6528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6529", + "filePath": "resourceFile6529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6530", + "filePath": "resourceFile6530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6531", + "filePath": "resourceFile6531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6532", + "filePath": "resourceFile6532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6533", + "filePath": "resourceFile6533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6534", + "filePath": "resourceFile6534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6535", + "filePath": "resourceFile6535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6536", + "filePath": "resourceFile6536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6537", + "filePath": "resourceFile6537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6538", + "filePath": "resourceFile6538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6539", + "filePath": "resourceFile6539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6540", + "filePath": "resourceFile6540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6541", + "filePath": "resourceFile6541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6542", + "filePath": "resourceFile6542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6543", + "filePath": "resourceFile6543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6544", + "filePath": "resourceFile6544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6545", + "filePath": "resourceFile6545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6546", + "filePath": "resourceFile6546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6547", + "filePath": "resourceFile6547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6548", + "filePath": "resourceFile6548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6549", + "filePath": "resourceFile6549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6550", + "filePath": "resourceFile6550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6551", + "filePath": "resourceFile6551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6552", + "filePath": "resourceFile6552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6553", + "filePath": "resourceFile6553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6554", + "filePath": "resourceFile6554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6555", + "filePath": "resourceFile6555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6556", + "filePath": "resourceFile6556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6557", + "filePath": "resourceFile6557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6558", + "filePath": "resourceFile6558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6559", + "filePath": "resourceFile6559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6560", + "filePath": "resourceFile6560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6561", + "filePath": "resourceFile6561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6562", + "filePath": "resourceFile6562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6563", + "filePath": "resourceFile6563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6564", + "filePath": "resourceFile6564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6565", + "filePath": "resourceFile6565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6566", + "filePath": "resourceFile6566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6567", + "filePath": "resourceFile6567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6568", + "filePath": "resourceFile6568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6569", + "filePath": "resourceFile6569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6570", + "filePath": "resourceFile6570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6571", + "filePath": "resourceFile6571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6572", + "filePath": "resourceFile6572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6573", + "filePath": "resourceFile6573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6574", + "filePath": "resourceFile6574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6575", + "filePath": "resourceFile6575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6576", + "filePath": "resourceFile6576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6577", + "filePath": "resourceFile6577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6578", + "filePath": "resourceFile6578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6579", + "filePath": "resourceFile6579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6580", + "filePath": "resourceFile6580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6581", + "filePath": "resourceFile6581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6582", + "filePath": "resourceFile6582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6583", + "filePath": "resourceFile6583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6584", + "filePath": "resourceFile6584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6585", + "filePath": "resourceFile6585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6586", + "filePath": "resourceFile6586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6587", + "filePath": "resourceFile6587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6588", + "filePath": "resourceFile6588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6589", + "filePath": "resourceFile6589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6590", + "filePath": "resourceFile6590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6591", + "filePath": "resourceFile6591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6592", + "filePath": "resourceFile6592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6593", + "filePath": "resourceFile6593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6594", + "filePath": "resourceFile6594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6595", + "filePath": "resourceFile6595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6596", + "filePath": "resourceFile6596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6597", + "filePath": "resourceFile6597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6598", + "filePath": "resourceFile6598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6599", + "filePath": "resourceFile6599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6600", + "filePath": "resourceFile6600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6601", + "filePath": "resourceFile6601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6602", + "filePath": "resourceFile6602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6603", + "filePath": "resourceFile6603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6604", + "filePath": "resourceFile6604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6605", + "filePath": "resourceFile6605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6606", + "filePath": "resourceFile6606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6607", + "filePath": "resourceFile6607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6608", + "filePath": "resourceFile6608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6609", + "filePath": "resourceFile6609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6610", + "filePath": "resourceFile6610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6611", + "filePath": "resourceFile6611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6612", + "filePath": "resourceFile6612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6613", + "filePath": "resourceFile6613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6614", + "filePath": "resourceFile6614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6615", + "filePath": "resourceFile6615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6616", + "filePath": "resourceFile6616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6617", + "filePath": "resourceFile6617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6618", + "filePath": "resourceFile6618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6619", + "filePath": "resourceFile6619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6620", + "filePath": "resourceFile6620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6621", + "filePath": "resourceFile6621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6622", + "filePath": "resourceFile6622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6623", + "filePath": "resourceFile6623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6624", + "filePath": "resourceFile6624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6625", + "filePath": "resourceFile6625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6626", + "filePath": "resourceFile6626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6627", + "filePath": "resourceFile6627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6628", + "filePath": "resourceFile6628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6629", + "filePath": "resourceFile6629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6630", + "filePath": "resourceFile6630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6631", + "filePath": "resourceFile6631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6632", + "filePath": "resourceFile6632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6633", + "filePath": "resourceFile6633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6634", + "filePath": "resourceFile6634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6635", + "filePath": "resourceFile6635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6636", + "filePath": "resourceFile6636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6637", + "filePath": "resourceFile6637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6638", + "filePath": "resourceFile6638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6639", + "filePath": "resourceFile6639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6640", + "filePath": "resourceFile6640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6641", + "filePath": "resourceFile6641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6642", + "filePath": "resourceFile6642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6643", + "filePath": "resourceFile6643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6644", + "filePath": "resourceFile6644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6645", + "filePath": "resourceFile6645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6646", + "filePath": "resourceFile6646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6647", + "filePath": "resourceFile6647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6648", + "filePath": "resourceFile6648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6649", + "filePath": "resourceFile6649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6650", + "filePath": "resourceFile6650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6651", + "filePath": "resourceFile6651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6652", + "filePath": "resourceFile6652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6653", + "filePath": "resourceFile6653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6654", + "filePath": "resourceFile6654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6655", + "filePath": "resourceFile6655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6656", + "filePath": "resourceFile6656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6657", + "filePath": "resourceFile6657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6658", + "filePath": "resourceFile6658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6659", + "filePath": "resourceFile6659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6660", + "filePath": "resourceFile6660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6661", + "filePath": "resourceFile6661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6662", + "filePath": "resourceFile6662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6663", + "filePath": "resourceFile6663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6664", + "filePath": "resourceFile6664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6665", + "filePath": "resourceFile6665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6666", + "filePath": "resourceFile6666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6667", + "filePath": "resourceFile6667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6668", + "filePath": "resourceFile6668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6669", + "filePath": "resourceFile6669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6670", + "filePath": "resourceFile6670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6671", + "filePath": "resourceFile6671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6672", + "filePath": "resourceFile6672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6673", + "filePath": "resourceFile6673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6674", + "filePath": "resourceFile6674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6675", + "filePath": "resourceFile6675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6676", + "filePath": "resourceFile6676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6677", + "filePath": "resourceFile6677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6678", + "filePath": "resourceFile6678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6679", + "filePath": "resourceFile6679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6680", + "filePath": "resourceFile6680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6681", + "filePath": "resourceFile6681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6682", + "filePath": "resourceFile6682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6683", + "filePath": "resourceFile6683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6684", + "filePath": "resourceFile6684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6685", + "filePath": "resourceFile6685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6686", + "filePath": "resourceFile6686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6687", + "filePath": "resourceFile6687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6688", + "filePath": "resourceFile6688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6689", + "filePath": "resourceFile6689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6690", + "filePath": "resourceFile6690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6691", + "filePath": "resourceFile6691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6692", + "filePath": "resourceFile6692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6693", + "filePath": "resourceFile6693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6694", + "filePath": "resourceFile6694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6695", + "filePath": "resourceFile6695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6696", + "filePath": "resourceFile6696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6697", + "filePath": "resourceFile6697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6698", + "filePath": "resourceFile6698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6699", + "filePath": "resourceFile6699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6700", + "filePath": "resourceFile6700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6701", + "filePath": "resourceFile6701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6702", + "filePath": "resourceFile6702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6703", + "filePath": "resourceFile6703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6704", + "filePath": "resourceFile6704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6705", + "filePath": "resourceFile6705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6706", + "filePath": "resourceFile6706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6707", + "filePath": "resourceFile6707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6708", + "filePath": "resourceFile6708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6709", + "filePath": "resourceFile6709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6710", + "filePath": "resourceFile6710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6711", + "filePath": "resourceFile6711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6712", + "filePath": "resourceFile6712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6713", + "filePath": "resourceFile6713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6714", + "filePath": "resourceFile6714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6715", + "filePath": "resourceFile6715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6716", + "filePath": "resourceFile6716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6717", + "filePath": "resourceFile6717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6718", + "filePath": "resourceFile6718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6719", + "filePath": "resourceFile6719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6720", + "filePath": "resourceFile6720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6721", + "filePath": "resourceFile6721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6722", + "filePath": "resourceFile6722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6723", + "filePath": "resourceFile6723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6724", + "filePath": "resourceFile6724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6725", + "filePath": "resourceFile6725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6726", + "filePath": "resourceFile6726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6727", + "filePath": "resourceFile6727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6728", + "filePath": "resourceFile6728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6729", + "filePath": "resourceFile6729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6730", + "filePath": "resourceFile6730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6731", + "filePath": "resourceFile6731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6732", + "filePath": "resourceFile6732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6733", + "filePath": "resourceFile6733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6734", + "filePath": "resourceFile6734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6735", + "filePath": "resourceFile6735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6736", + "filePath": "resourceFile6736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6737", + "filePath": "resourceFile6737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6738", + "filePath": "resourceFile6738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6739", + "filePath": "resourceFile6739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6740", + "filePath": "resourceFile6740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6741", + "filePath": "resourceFile6741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6742", + "filePath": "resourceFile6742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6743", + "filePath": "resourceFile6743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6744", + "filePath": "resourceFile6744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6745", + "filePath": "resourceFile6745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6746", + "filePath": "resourceFile6746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6747", + "filePath": "resourceFile6747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6748", + "filePath": "resourceFile6748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6749", + "filePath": "resourceFile6749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6750", + "filePath": "resourceFile6750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6751", + "filePath": "resourceFile6751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6752", + "filePath": "resourceFile6752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6753", + "filePath": "resourceFile6753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6754", + "filePath": "resourceFile6754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6755", + "filePath": "resourceFile6755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6756", + "filePath": "resourceFile6756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6757", + "filePath": "resourceFile6757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6758", + "filePath": "resourceFile6758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6759", + "filePath": "resourceFile6759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6760", + "filePath": "resourceFile6760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6761", + "filePath": "resourceFile6761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6762", + "filePath": "resourceFile6762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6763", + "filePath": "resourceFile6763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6764", + "filePath": "resourceFile6764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6765", + "filePath": "resourceFile6765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6766", + "filePath": "resourceFile6766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6767", + "filePath": "resourceFile6767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6768", + "filePath": "resourceFile6768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6769", + "filePath": "resourceFile6769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6770", + "filePath": "resourceFile6770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6771", + "filePath": "resourceFile6771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6772", + "filePath": "resourceFile6772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6773", + "filePath": "resourceFile6773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6774", + "filePath": "resourceFile6774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6775", + "filePath": "resourceFile6775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6776", + "filePath": "resourceFile6776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6777", + "filePath": "resourceFile6777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6778", + "filePath": "resourceFile6778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6779", + "filePath": "resourceFile6779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6780", + "filePath": "resourceFile6780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6781", + "filePath": "resourceFile6781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6782", + "filePath": "resourceFile6782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6783", + "filePath": "resourceFile6783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6784", + "filePath": "resourceFile6784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6785", + "filePath": "resourceFile6785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6786", + "filePath": "resourceFile6786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6787", + "filePath": "resourceFile6787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6788", + "filePath": "resourceFile6788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6789", + "filePath": "resourceFile6789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6790", + "filePath": "resourceFile6790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6791", + "filePath": "resourceFile6791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6792", + "filePath": "resourceFile6792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6793", + "filePath": "resourceFile6793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6794", + "filePath": "resourceFile6794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6795", + "filePath": "resourceFile6795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6796", + "filePath": "resourceFile6796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6797", + "filePath": "resourceFile6797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6798", + "filePath": "resourceFile6798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6799", + "filePath": "resourceFile6799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6800", + "filePath": "resourceFile6800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6801", + "filePath": "resourceFile6801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6802", + "filePath": "resourceFile6802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6803", + "filePath": "resourceFile6803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6804", + "filePath": "resourceFile6804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6805", + "filePath": "resourceFile6805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6806", + "filePath": "resourceFile6806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6807", + "filePath": "resourceFile6807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6808", + "filePath": "resourceFile6808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6809", + "filePath": "resourceFile6809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6810", + "filePath": "resourceFile6810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6811", + "filePath": "resourceFile6811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6812", + "filePath": "resourceFile6812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6813", + "filePath": "resourceFile6813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6814", + "filePath": "resourceFile6814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6815", + "filePath": "resourceFile6815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6816", + "filePath": "resourceFile6816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6817", + "filePath": "resourceFile6817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6818", + "filePath": "resourceFile6818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6819", + "filePath": "resourceFile6819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6820", + "filePath": "resourceFile6820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6821", + "filePath": "resourceFile6821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6822", + "filePath": "resourceFile6822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6823", + "filePath": "resourceFile6823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6824", + "filePath": "resourceFile6824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6825", + "filePath": "resourceFile6825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6826", + "filePath": "resourceFile6826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6827", + "filePath": "resourceFile6827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6828", + "filePath": "resourceFile6828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6829", + "filePath": "resourceFile6829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6830", + "filePath": "resourceFile6830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6831", + "filePath": "resourceFile6831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6832", + "filePath": "resourceFile6832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6833", + "filePath": "resourceFile6833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6834", + "filePath": "resourceFile6834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6835", + "filePath": "resourceFile6835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6836", + "filePath": "resourceFile6836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6837", + "filePath": "resourceFile6837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6838", + "filePath": "resourceFile6838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6839", + "filePath": "resourceFile6839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6840", + "filePath": "resourceFile6840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6841", + "filePath": "resourceFile6841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6842", + "filePath": "resourceFile6842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6843", + "filePath": "resourceFile6843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6844", + "filePath": "resourceFile6844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6845", + "filePath": "resourceFile6845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6846", + "filePath": "resourceFile6846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6847", + "filePath": "resourceFile6847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6848", + "filePath": "resourceFile6848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6849", + "filePath": "resourceFile6849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6850", + "filePath": "resourceFile6850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6851", + "filePath": "resourceFile6851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6852", + "filePath": "resourceFile6852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6853", + "filePath": "resourceFile6853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6854", + "filePath": "resourceFile6854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6855", + "filePath": "resourceFile6855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6856", + "filePath": "resourceFile6856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6857", + "filePath": "resourceFile6857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6858", + "filePath": "resourceFile6858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6859", + "filePath": "resourceFile6859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6860", + "filePath": "resourceFile6860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6861", + "filePath": "resourceFile6861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6862", + "filePath": "resourceFile6862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6863", + "filePath": "resourceFile6863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6864", + "filePath": "resourceFile6864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6865", + "filePath": "resourceFile6865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6866", + "filePath": "resourceFile6866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6867", + "filePath": "resourceFile6867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6868", + "filePath": "resourceFile6868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6869", + "filePath": "resourceFile6869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6870", + "filePath": "resourceFile6870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6871", + "filePath": "resourceFile6871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6872", + "filePath": "resourceFile6872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6873", + "filePath": "resourceFile6873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6874", + "filePath": "resourceFile6874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6875", + "filePath": "resourceFile6875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6876", + "filePath": "resourceFile6876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6877", + "filePath": "resourceFile6877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6878", + "filePath": "resourceFile6878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6879", + "filePath": "resourceFile6879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6880", + "filePath": "resourceFile6880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6881", + "filePath": "resourceFile6881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6882", + "filePath": "resourceFile6882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6883", + "filePath": "resourceFile6883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6884", + "filePath": "resourceFile6884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6885", + "filePath": "resourceFile6885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6886", + "filePath": "resourceFile6886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6887", + "filePath": "resourceFile6887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6888", + "filePath": "resourceFile6888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6889", + "filePath": "resourceFile6889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6890", + "filePath": "resourceFile6890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6891", + "filePath": "resourceFile6891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6892", + "filePath": "resourceFile6892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6893", + "filePath": "resourceFile6893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6894", + "filePath": "resourceFile6894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6895", + "filePath": "resourceFile6895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6896", + "filePath": "resourceFile6896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6897", + "filePath": "resourceFile6897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6898", + "filePath": "resourceFile6898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6899", + "filePath": "resourceFile6899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6900", + "filePath": "resourceFile6900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6901", + "filePath": "resourceFile6901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6902", + "filePath": "resourceFile6902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6903", + "filePath": "resourceFile6903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6904", + "filePath": "resourceFile6904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6905", + "filePath": "resourceFile6905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6906", + "filePath": "resourceFile6906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6907", + "filePath": "resourceFile6907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6908", + "filePath": "resourceFile6908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6909", + "filePath": "resourceFile6909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6910", + "filePath": "resourceFile6910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6911", + "filePath": "resourceFile6911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6912", + "filePath": "resourceFile6912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6913", + "filePath": "resourceFile6913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6914", + "filePath": "resourceFile6914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6915", + "filePath": "resourceFile6915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6916", + "filePath": "resourceFile6916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6917", + "filePath": "resourceFile6917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6918", + "filePath": "resourceFile6918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6919", + "filePath": "resourceFile6919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6920", + "filePath": "resourceFile6920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6921", + "filePath": "resourceFile6921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6922", + "filePath": "resourceFile6922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6923", + "filePath": "resourceFile6923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6924", + "filePath": "resourceFile6924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6925", + "filePath": "resourceFile6925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6926", + "filePath": "resourceFile6926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6927", + "filePath": "resourceFile6927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6928", + "filePath": "resourceFile6928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6929", + "filePath": "resourceFile6929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6930", + "filePath": "resourceFile6930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6931", + "filePath": "resourceFile6931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6932", + "filePath": "resourceFile6932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6933", + "filePath": "resourceFile6933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6934", + "filePath": "resourceFile6934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6935", + "filePath": "resourceFile6935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6936", + "filePath": "resourceFile6936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6937", + "filePath": "resourceFile6937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6938", + "filePath": "resourceFile6938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6939", + "filePath": "resourceFile6939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6940", + "filePath": "resourceFile6940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6941", + "filePath": "resourceFile6941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6942", + "filePath": "resourceFile6942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6943", + "filePath": "resourceFile6943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6944", + "filePath": "resourceFile6944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6945", + "filePath": "resourceFile6945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6946", + "filePath": "resourceFile6946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6947", + "filePath": "resourceFile6947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6948", + "filePath": "resourceFile6948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6949", + "filePath": "resourceFile6949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6950", + "filePath": "resourceFile6950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6951", + "filePath": "resourceFile6951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6952", + "filePath": "resourceFile6952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6953", + "filePath": "resourceFile6953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6954", + "filePath": "resourceFile6954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6955", + "filePath": "resourceFile6955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6956", + "filePath": "resourceFile6956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6957", + "filePath": "resourceFile6957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6958", + "filePath": "resourceFile6958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6959", + "filePath": "resourceFile6959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6960", + "filePath": "resourceFile6960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6961", + "filePath": "resourceFile6961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6962", + "filePath": "resourceFile6962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6963", + "filePath": "resourceFile6963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6964", + "filePath": "resourceFile6964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6965", + "filePath": "resourceFile6965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6966", + "filePath": "resourceFile6966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6967", + "filePath": "resourceFile6967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6968", + "filePath": "resourceFile6968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6969", + "filePath": "resourceFile6969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6970", + "filePath": "resourceFile6970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6971", + "filePath": "resourceFile6971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6972", + "filePath": "resourceFile6972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6973", + "filePath": "resourceFile6973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6974", + "filePath": "resourceFile6974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6975", + "filePath": "resourceFile6975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6976", + "filePath": "resourceFile6976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6977", + "filePath": "resourceFile6977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6978", + "filePath": "resourceFile6978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6979", + "filePath": "resourceFile6979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6980", + "filePath": "resourceFile6980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6981", + "filePath": "resourceFile6981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6982", + "filePath": "resourceFile6982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6983", + "filePath": "resourceFile6983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6984", + "filePath": "resourceFile6984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6985", + "filePath": "resourceFile6985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6986", + "filePath": "resourceFile6986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6987", + "filePath": "resourceFile6987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6988", + "filePath": "resourceFile6988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6989", + "filePath": "resourceFile6989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6990", + "filePath": "resourceFile6990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6991", + "filePath": "resourceFile6991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6992", + "filePath": "resourceFile6992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6993", + "filePath": "resourceFile6993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6994", + "filePath": "resourceFile6994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6995", + "filePath": "resourceFile6995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6996", + "filePath": "resourceFile6996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6997", + "filePath": "resourceFile6997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6998", + "filePath": "resourceFile6998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6999", + "filePath": "resourceFile6999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7000", + "filePath": "resourceFile7000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7001", + "filePath": "resourceFile7001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7002", + "filePath": "resourceFile7002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7003", + "filePath": "resourceFile7003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7004", + "filePath": "resourceFile7004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7005", + "filePath": "resourceFile7005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7006", + "filePath": "resourceFile7006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7007", + "filePath": "resourceFile7007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7008", + "filePath": "resourceFile7008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7009", + "filePath": "resourceFile7009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7010", + "filePath": "resourceFile7010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7011", + "filePath": "resourceFile7011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7012", + "filePath": "resourceFile7012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7013", + "filePath": "resourceFile7013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7014", + "filePath": "resourceFile7014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7015", + "filePath": "resourceFile7015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7016", + "filePath": "resourceFile7016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7017", + "filePath": "resourceFile7017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7018", + "filePath": "resourceFile7018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7019", + "filePath": "resourceFile7019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7020", + "filePath": "resourceFile7020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7021", + "filePath": "resourceFile7021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7022", + "filePath": "resourceFile7022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7023", + "filePath": "resourceFile7023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7024", + "filePath": "resourceFile7024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7025", + "filePath": "resourceFile7025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7026", + "filePath": "resourceFile7026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7027", + "filePath": "resourceFile7027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7028", + "filePath": "resourceFile7028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7029", + "filePath": "resourceFile7029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7030", + "filePath": "resourceFile7030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7031", + "filePath": "resourceFile7031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7032", + "filePath": "resourceFile7032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7033", + "filePath": "resourceFile7033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7034", + "filePath": "resourceFile7034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7035", + "filePath": "resourceFile7035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7036", + "filePath": "resourceFile7036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7037", + "filePath": "resourceFile7037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7038", + "filePath": "resourceFile7038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7039", + "filePath": "resourceFile7039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7040", + "filePath": "resourceFile7040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7041", + "filePath": "resourceFile7041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7042", + "filePath": "resourceFile7042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7043", + "filePath": "resourceFile7043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7044", + "filePath": "resourceFile7044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7045", + "filePath": "resourceFile7045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7046", + "filePath": "resourceFile7046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7047", + "filePath": "resourceFile7047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7048", + "filePath": "resourceFile7048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7049", + "filePath": "resourceFile7049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7050", + "filePath": "resourceFile7050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7051", + "filePath": "resourceFile7051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7052", + "filePath": "resourceFile7052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7053", + "filePath": "resourceFile7053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7054", + "filePath": "resourceFile7054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7055", + "filePath": "resourceFile7055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7056", + "filePath": "resourceFile7056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7057", + "filePath": "resourceFile7057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7058", + "filePath": "resourceFile7058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7059", + "filePath": "resourceFile7059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7060", + "filePath": "resourceFile7060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7061", + "filePath": "resourceFile7061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7062", + "filePath": "resourceFile7062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7063", + "filePath": "resourceFile7063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7064", + "filePath": "resourceFile7064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7065", + "filePath": "resourceFile7065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7066", + "filePath": "resourceFile7066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7067", + "filePath": "resourceFile7067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7068", + "filePath": "resourceFile7068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7069", + "filePath": "resourceFile7069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7070", + "filePath": "resourceFile7070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7071", + "filePath": "resourceFile7071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7072", + "filePath": "resourceFile7072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7073", + "filePath": "resourceFile7073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7074", + "filePath": "resourceFile7074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7075", + "filePath": "resourceFile7075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7076", + "filePath": "resourceFile7076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7077", + "filePath": "resourceFile7077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7078", + "filePath": "resourceFile7078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7079", + "filePath": "resourceFile7079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7080", + "filePath": "resourceFile7080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7081", + "filePath": "resourceFile7081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7082", + "filePath": "resourceFile7082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7083", + "filePath": "resourceFile7083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7084", + "filePath": "resourceFile7084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7085", + "filePath": "resourceFile7085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7086", + "filePath": "resourceFile7086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7087", + "filePath": "resourceFile7087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7088", + "filePath": "resourceFile7088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7089", + "filePath": "resourceFile7089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7090", + "filePath": "resourceFile7090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7091", + "filePath": "resourceFile7091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7092", + "filePath": "resourceFile7092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7093", + "filePath": "resourceFile7093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7094", + "filePath": "resourceFile7094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7095", + "filePath": "resourceFile7095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7096", + "filePath": "resourceFile7096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7097", + "filePath": "resourceFile7097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7098", + "filePath": "resourceFile7098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7099", + "filePath": "resourceFile7099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7100", + "filePath": "resourceFile7100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7101", + "filePath": "resourceFile7101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7102", + "filePath": "resourceFile7102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7103", + "filePath": "resourceFile7103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7104", + "filePath": "resourceFile7104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7105", + "filePath": "resourceFile7105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7106", + "filePath": "resourceFile7106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7107", + "filePath": "resourceFile7107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7108", + "filePath": "resourceFile7108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7109", + "filePath": "resourceFile7109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7110", + "filePath": "resourceFile7110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7111", + "filePath": "resourceFile7111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7112", + "filePath": "resourceFile7112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7113", + "filePath": "resourceFile7113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7114", + "filePath": "resourceFile7114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7115", + "filePath": "resourceFile7115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7116", + "filePath": "resourceFile7116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7117", + "filePath": "resourceFile7117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7118", + "filePath": "resourceFile7118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7119", + "filePath": "resourceFile7119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7120", + "filePath": "resourceFile7120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7121", + "filePath": "resourceFile7121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7122", + "filePath": "resourceFile7122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7123", + "filePath": "resourceFile7123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7124", + "filePath": "resourceFile7124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7125", + "filePath": "resourceFile7125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7126", + "filePath": "resourceFile7126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7127", + "filePath": "resourceFile7127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7128", + "filePath": "resourceFile7128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7129", + "filePath": "resourceFile7129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7130", + "filePath": "resourceFile7130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7131", + "filePath": "resourceFile7131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7132", + "filePath": "resourceFile7132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7133", + "filePath": "resourceFile7133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7134", + "filePath": "resourceFile7134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7135", + "filePath": "resourceFile7135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7136", + "filePath": "resourceFile7136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7137", + "filePath": "resourceFile7137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7138", + "filePath": "resourceFile7138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7139", + "filePath": "resourceFile7139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7140", + "filePath": "resourceFile7140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7141", + "filePath": "resourceFile7141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7142", + "filePath": "resourceFile7142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7143", + "filePath": "resourceFile7143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7144", + "filePath": "resourceFile7144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7145", + "filePath": "resourceFile7145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7146", + "filePath": "resourceFile7146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7147", + "filePath": "resourceFile7147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7148", + "filePath": "resourceFile7148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7149", + "filePath": "resourceFile7149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7150", + "filePath": "resourceFile7150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7151", + "filePath": "resourceFile7151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7152", + "filePath": "resourceFile7152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7153", + "filePath": "resourceFile7153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7154", + "filePath": "resourceFile7154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7155", + "filePath": "resourceFile7155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7156", + "filePath": "resourceFile7156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7157", + "filePath": "resourceFile7157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7158", + "filePath": "resourceFile7158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7159", + "filePath": "resourceFile7159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7160", + "filePath": "resourceFile7160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7161", + "filePath": "resourceFile7161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7162", + "filePath": "resourceFile7162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7163", + "filePath": "resourceFile7163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7164", + "filePath": "resourceFile7164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7165", + "filePath": "resourceFile7165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7166", + "filePath": "resourceFile7166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7167", + "filePath": "resourceFile7167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7168", + "filePath": "resourceFile7168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7169", + "filePath": "resourceFile7169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7170", + "filePath": "resourceFile7170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7171", + "filePath": "resourceFile7171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7172", + "filePath": "resourceFile7172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7173", + "filePath": "resourceFile7173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7174", + "filePath": "resourceFile7174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7175", + "filePath": "resourceFile7175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7176", + "filePath": "resourceFile7176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7177", + "filePath": "resourceFile7177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7178", + "filePath": "resourceFile7178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7179", + "filePath": "resourceFile7179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7180", + "filePath": "resourceFile7180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7181", + "filePath": "resourceFile7181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7182", + "filePath": "resourceFile7182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7183", + "filePath": "resourceFile7183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7184", + "filePath": "resourceFile7184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7185", + "filePath": "resourceFile7185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7186", + "filePath": "resourceFile7186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7187", + "filePath": "resourceFile7187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7188", + "filePath": "resourceFile7188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7189", + "filePath": "resourceFile7189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7190", + "filePath": "resourceFile7190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7191", + "filePath": "resourceFile7191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7192", + "filePath": "resourceFile7192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7193", + "filePath": "resourceFile7193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7194", + "filePath": "resourceFile7194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7195", + "filePath": "resourceFile7195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7196", + "filePath": "resourceFile7196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7197", + "filePath": "resourceFile7197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7198", + "filePath": "resourceFile7198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7199", + "filePath": "resourceFile7199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7200", + "filePath": "resourceFile7200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7201", + "filePath": "resourceFile7201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7202", + "filePath": "resourceFile7202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7203", + "filePath": "resourceFile7203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7204", + "filePath": "resourceFile7204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7205", + "filePath": "resourceFile7205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7206", + "filePath": "resourceFile7206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7207", + "filePath": "resourceFile7207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7208", + "filePath": "resourceFile7208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7209", + "filePath": "resourceFile7209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7210", + "filePath": "resourceFile7210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7211", + "filePath": "resourceFile7211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7212", + "filePath": "resourceFile7212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7213", + "filePath": "resourceFile7213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7214", + "filePath": "resourceFile7214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7215", + "filePath": "resourceFile7215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7216", + "filePath": "resourceFile7216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7217", + "filePath": "resourceFile7217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7218", + "filePath": "resourceFile7218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7219", + "filePath": "resourceFile7219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7220", + "filePath": "resourceFile7220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7221", + "filePath": "resourceFile7221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7222", + "filePath": "resourceFile7222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7223", + "filePath": "resourceFile7223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7224", + "filePath": "resourceFile7224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7225", + "filePath": "resourceFile7225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7226", + "filePath": "resourceFile7226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7227", + "filePath": "resourceFile7227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7228", + "filePath": "resourceFile7228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7229", + "filePath": "resourceFile7229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7230", + "filePath": "resourceFile7230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7231", + "filePath": "resourceFile7231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7232", + "filePath": "resourceFile7232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7233", + "filePath": "resourceFile7233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7234", + "filePath": "resourceFile7234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7235", + "filePath": "resourceFile7235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7236", + "filePath": "resourceFile7236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7237", + "filePath": "resourceFile7237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7238", + "filePath": "resourceFile7238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7239", + "filePath": "resourceFile7239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7240", + "filePath": "resourceFile7240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7241", + "filePath": "resourceFile7241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7242", + "filePath": "resourceFile7242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7243", + "filePath": "resourceFile7243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7244", + "filePath": "resourceFile7244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7245", + "filePath": "resourceFile7245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7246", + "filePath": "resourceFile7246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7247", + "filePath": "resourceFile7247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7248", + "filePath": "resourceFile7248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7249", + "filePath": "resourceFile7249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7250", + "filePath": "resourceFile7250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7251", + "filePath": "resourceFile7251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7252", + "filePath": "resourceFile7252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7253", + "filePath": "resourceFile7253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7254", + "filePath": "resourceFile7254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7255", + "filePath": "resourceFile7255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7256", + "filePath": "resourceFile7256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7257", + "filePath": "resourceFile7257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7258", + "filePath": "resourceFile7258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7259", + "filePath": "resourceFile7259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7260", + "filePath": "resourceFile7260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7261", + "filePath": "resourceFile7261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7262", + "filePath": "resourceFile7262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7263", + "filePath": "resourceFile7263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7264", + "filePath": "resourceFile7264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7265", + "filePath": "resourceFile7265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7266", + "filePath": "resourceFile7266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7267", + "filePath": "resourceFile7267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7268", + "filePath": "resourceFile7268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7269", + "filePath": "resourceFile7269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7270", + "filePath": "resourceFile7270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7271", + "filePath": "resourceFile7271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7272", + "filePath": "resourceFile7272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7273", + "filePath": "resourceFile7273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7274", + "filePath": "resourceFile7274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7275", + "filePath": "resourceFile7275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7276", + "filePath": "resourceFile7276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7277", + "filePath": "resourceFile7277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7278", + "filePath": "resourceFile7278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7279", + "filePath": "resourceFile7279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7280", + "filePath": "resourceFile7280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7281", + "filePath": "resourceFile7281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7282", + "filePath": "resourceFile7282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7283", + "filePath": "resourceFile7283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7284", + "filePath": "resourceFile7284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7285", + "filePath": "resourceFile7285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7286", + "filePath": "resourceFile7286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7287", + "filePath": "resourceFile7287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7288", + "filePath": "resourceFile7288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7289", + "filePath": "resourceFile7289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7290", + "filePath": "resourceFile7290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7291", + "filePath": "resourceFile7291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7292", + "filePath": "resourceFile7292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7293", + "filePath": "resourceFile7293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7294", + "filePath": "resourceFile7294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7295", + "filePath": "resourceFile7295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7296", + "filePath": "resourceFile7296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7297", + "filePath": "resourceFile7297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7298", + "filePath": "resourceFile7298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7299", + "filePath": "resourceFile7299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7300", + "filePath": "resourceFile7300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7301", + "filePath": "resourceFile7301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7302", + "filePath": "resourceFile7302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7303", + "filePath": "resourceFile7303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7304", + "filePath": "resourceFile7304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7305", + "filePath": "resourceFile7305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7306", + "filePath": "resourceFile7306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7307", + "filePath": "resourceFile7307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7308", + "filePath": "resourceFile7308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7309", + "filePath": "resourceFile7309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7310", + "filePath": "resourceFile7310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7311", + "filePath": "resourceFile7311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7312", + "filePath": "resourceFile7312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7313", + "filePath": "resourceFile7313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7314", + "filePath": "resourceFile7314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7315", + "filePath": "resourceFile7315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7316", + "filePath": "resourceFile7316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7317", + "filePath": "resourceFile7317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7318", + "filePath": "resourceFile7318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7319", + "filePath": "resourceFile7319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7320", + "filePath": "resourceFile7320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7321", + "filePath": "resourceFile7321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7322", + "filePath": "resourceFile7322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7323", + "filePath": "resourceFile7323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7324", + "filePath": "resourceFile7324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7325", + "filePath": "resourceFile7325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7326", + "filePath": "resourceFile7326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7327", + "filePath": "resourceFile7327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7328", + "filePath": "resourceFile7328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7329", + "filePath": "resourceFile7329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7330", + "filePath": "resourceFile7330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7331", + "filePath": "resourceFile7331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7332", + "filePath": "resourceFile7332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7333", + "filePath": "resourceFile7333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7334", + "filePath": "resourceFile7334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7335", + "filePath": "resourceFile7335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7336", + "filePath": "resourceFile7336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7337", + "filePath": "resourceFile7337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7338", + "filePath": "resourceFile7338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7339", + "filePath": "resourceFile7339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7340", + "filePath": "resourceFile7340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7341", + "filePath": "resourceFile7341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7342", + "filePath": "resourceFile7342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7343", + "filePath": "resourceFile7343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7344", + "filePath": "resourceFile7344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7345", + "filePath": "resourceFile7345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7346", + "filePath": "resourceFile7346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7347", + "filePath": "resourceFile7347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7348", + "filePath": "resourceFile7348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7349", + "filePath": "resourceFile7349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7350", + "filePath": "resourceFile7350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7351", + "filePath": "resourceFile7351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7352", + "filePath": "resourceFile7352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7353", + "filePath": "resourceFile7353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7354", + "filePath": "resourceFile7354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7355", + "filePath": "resourceFile7355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7356", + "filePath": "resourceFile7356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7357", + "filePath": "resourceFile7357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7358", + "filePath": "resourceFile7358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7359", + "filePath": "resourceFile7359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7360", + "filePath": "resourceFile7360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7361", + "filePath": "resourceFile7361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7362", + "filePath": "resourceFile7362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7363", + "filePath": "resourceFile7363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7364", + "filePath": "resourceFile7364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7365", + "filePath": "resourceFile7365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7366", + "filePath": "resourceFile7366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7367", + "filePath": "resourceFile7367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7368", + "filePath": "resourceFile7368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7369", + "filePath": "resourceFile7369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7370", + "filePath": "resourceFile7370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7371", + "filePath": "resourceFile7371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7372", + "filePath": "resourceFile7372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7373", + "filePath": "resourceFile7373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7374", + "filePath": "resourceFile7374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7375", + "filePath": "resourceFile7375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7376", + "filePath": "resourceFile7376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7377", + "filePath": "resourceFile7377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7378", + "filePath": "resourceFile7378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7379", + "filePath": "resourceFile7379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7380", + "filePath": "resourceFile7380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7381", + "filePath": "resourceFile7381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7382", + "filePath": "resourceFile7382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7383", + "filePath": "resourceFile7383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7384", + "filePath": "resourceFile7384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7385", + "filePath": "resourceFile7385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7386", + "filePath": "resourceFile7386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7387", + "filePath": "resourceFile7387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7388", + "filePath": "resourceFile7388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7389", + "filePath": "resourceFile7389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7390", + "filePath": "resourceFile7390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7391", + "filePath": "resourceFile7391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7392", + "filePath": "resourceFile7392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7393", + "filePath": "resourceFile7393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7394", + "filePath": "resourceFile7394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7395", + "filePath": "resourceFile7395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7396", + "filePath": "resourceFile7396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7397", + "filePath": "resourceFile7397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7398", + "filePath": "resourceFile7398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7399", + "filePath": "resourceFile7399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7400", + "filePath": "resourceFile7400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7401", + "filePath": "resourceFile7401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7402", + "filePath": "resourceFile7402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7403", + "filePath": "resourceFile7403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7404", + "filePath": "resourceFile7404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7405", + "filePath": "resourceFile7405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7406", + "filePath": "resourceFile7406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7407", + "filePath": "resourceFile7407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7408", + "filePath": "resourceFile7408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7409", + "filePath": "resourceFile7409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7410", + "filePath": "resourceFile7410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7411", + "filePath": "resourceFile7411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7412", + "filePath": "resourceFile7412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7413", + "filePath": "resourceFile7413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7414", + "filePath": "resourceFile7414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7415", + "filePath": "resourceFile7415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7416", + "filePath": "resourceFile7416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7417", + "filePath": "resourceFile7417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7418", + "filePath": "resourceFile7418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7419", + "filePath": "resourceFile7419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7420", + "filePath": "resourceFile7420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7421", + "filePath": "resourceFile7421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7422", + "filePath": "resourceFile7422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7423", + "filePath": "resourceFile7423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7424", + "filePath": "resourceFile7424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7425", + "filePath": "resourceFile7425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7426", + "filePath": "resourceFile7426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7427", + "filePath": "resourceFile7427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7428", + "filePath": "resourceFile7428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7429", + "filePath": "resourceFile7429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7430", + "filePath": "resourceFile7430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7431", + "filePath": "resourceFile7431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7432", + "filePath": "resourceFile7432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7433", + "filePath": "resourceFile7433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7434", + "filePath": "resourceFile7434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7435", + "filePath": "resourceFile7435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7436", + "filePath": "resourceFile7436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7437", + "filePath": "resourceFile7437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7438", + "filePath": "resourceFile7438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7439", + "filePath": "resourceFile7439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7440", + "filePath": "resourceFile7440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7441", + "filePath": "resourceFile7441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7442", + "filePath": "resourceFile7442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7443", + "filePath": "resourceFile7443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7444", + "filePath": "resourceFile7444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7445", + "filePath": "resourceFile7445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7446", + "filePath": "resourceFile7446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7447", + "filePath": "resourceFile7447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7448", + "filePath": "resourceFile7448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7449", + "filePath": "resourceFile7449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7450", + "filePath": "resourceFile7450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7451", + "filePath": "resourceFile7451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7452", + "filePath": "resourceFile7452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7453", + "filePath": "resourceFile7453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7454", + "filePath": "resourceFile7454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7455", + "filePath": "resourceFile7455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7456", + "filePath": "resourceFile7456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7457", + "filePath": "resourceFile7457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7458", + "filePath": "resourceFile7458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7459", + "filePath": "resourceFile7459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7460", + "filePath": "resourceFile7460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7461", + "filePath": "resourceFile7461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7462", + "filePath": "resourceFile7462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7463", + "filePath": "resourceFile7463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7464", + "filePath": "resourceFile7464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7465", + "filePath": "resourceFile7465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7466", + "filePath": "resourceFile7466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7467", + "filePath": "resourceFile7467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7468", + "filePath": "resourceFile7468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7469", + "filePath": "resourceFile7469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7470", + "filePath": "resourceFile7470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7471", + "filePath": "resourceFile7471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7472", + "filePath": "resourceFile7472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7473", + "filePath": "resourceFile7473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7474", + "filePath": "resourceFile7474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7475", + "filePath": "resourceFile7475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7476", + "filePath": "resourceFile7476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7477", + "filePath": "resourceFile7477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7478", + "filePath": "resourceFile7478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7479", + "filePath": "resourceFile7479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7480", + "filePath": "resourceFile7480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7481", + "filePath": "resourceFile7481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7482", + "filePath": "resourceFile7482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7483", + "filePath": "resourceFile7483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7484", + "filePath": "resourceFile7484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7485", + "filePath": "resourceFile7485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7486", + "filePath": "resourceFile7486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7487", + "filePath": "resourceFile7487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7488", + "filePath": "resourceFile7488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7489", + "filePath": "resourceFile7489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7490", + "filePath": "resourceFile7490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7491", + "filePath": "resourceFile7491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7492", + "filePath": "resourceFile7492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7493", + "filePath": "resourceFile7493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7494", + "filePath": "resourceFile7494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7495", + "filePath": "resourceFile7495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7496", + "filePath": "resourceFile7496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7497", + "filePath": "resourceFile7497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7498", + "filePath": "resourceFile7498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7499", + "filePath": "resourceFile7499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7500", + "filePath": "resourceFile7500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7501", + "filePath": "resourceFile7501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7502", + "filePath": "resourceFile7502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7503", + "filePath": "resourceFile7503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7504", + "filePath": "resourceFile7504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7505", + "filePath": "resourceFile7505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7506", + "filePath": "resourceFile7506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7507", + "filePath": "resourceFile7507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7508", + "filePath": "resourceFile7508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7509", + "filePath": "resourceFile7509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7510", + "filePath": "resourceFile7510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7511", + "filePath": "resourceFile7511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7512", + "filePath": "resourceFile7512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7513", + "filePath": "resourceFile7513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7514", + "filePath": "resourceFile7514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7515", + "filePath": "resourceFile7515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7516", + "filePath": "resourceFile7516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7517", + "filePath": "resourceFile7517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7518", + "filePath": "resourceFile7518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7519", + "filePath": "resourceFile7519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7520", + "filePath": "resourceFile7520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7521", + "filePath": "resourceFile7521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7522", + "filePath": "resourceFile7522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7523", + "filePath": "resourceFile7523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7524", + "filePath": "resourceFile7524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7525", + "filePath": "resourceFile7525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7526", + "filePath": "resourceFile7526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7527", + "filePath": "resourceFile7527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7528", + "filePath": "resourceFile7528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7529", + "filePath": "resourceFile7529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7530", + "filePath": "resourceFile7530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7531", + "filePath": "resourceFile7531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7532", + "filePath": "resourceFile7532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7533", + "filePath": "resourceFile7533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7534", + "filePath": "resourceFile7534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7535", + "filePath": "resourceFile7535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7536", + "filePath": "resourceFile7536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7537", + "filePath": "resourceFile7537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7538", + "filePath": "resourceFile7538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7539", + "filePath": "resourceFile7539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7540", + "filePath": "resourceFile7540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7541", + "filePath": "resourceFile7541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7542", + "filePath": "resourceFile7542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7543", + "filePath": "resourceFile7543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7544", + "filePath": "resourceFile7544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7545", + "filePath": "resourceFile7545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7546", + "filePath": "resourceFile7546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7547", + "filePath": "resourceFile7547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7548", + "filePath": "resourceFile7548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7549", + "filePath": "resourceFile7549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7550", + "filePath": "resourceFile7550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7551", + "filePath": "resourceFile7551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7552", + "filePath": "resourceFile7552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7553", + "filePath": "resourceFile7553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7554", + "filePath": "resourceFile7554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7555", + "filePath": "resourceFile7555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7556", + "filePath": "resourceFile7556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7557", + "filePath": "resourceFile7557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7558", + "filePath": "resourceFile7558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7559", + "filePath": "resourceFile7559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7560", + "filePath": "resourceFile7560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7561", + "filePath": "resourceFile7561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7562", + "filePath": "resourceFile7562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7563", + "filePath": "resourceFile7563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7564", + "filePath": "resourceFile7564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7565", + "filePath": "resourceFile7565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7566", + "filePath": "resourceFile7566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7567", + "filePath": "resourceFile7567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7568", + "filePath": "resourceFile7568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7569", + "filePath": "resourceFile7569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7570", + "filePath": "resourceFile7570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7571", + "filePath": "resourceFile7571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7572", + "filePath": "resourceFile7572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7573", + "filePath": "resourceFile7573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7574", + "filePath": "resourceFile7574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7575", + "filePath": "resourceFile7575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7576", + "filePath": "resourceFile7576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7577", + "filePath": "resourceFile7577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7578", + "filePath": "resourceFile7578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7579", + "filePath": "resourceFile7579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7580", + "filePath": "resourceFile7580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7581", + "filePath": "resourceFile7581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7582", + "filePath": "resourceFile7582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7583", + "filePath": "resourceFile7583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7584", + "filePath": "resourceFile7584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7585", + "filePath": "resourceFile7585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7586", + "filePath": "resourceFile7586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7587", + "filePath": "resourceFile7587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7588", + "filePath": "resourceFile7588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7589", + "filePath": "resourceFile7589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7590", + "filePath": "resourceFile7590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7591", + "filePath": "resourceFile7591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7592", + "filePath": "resourceFile7592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7593", + "filePath": "resourceFile7593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7594", + "filePath": "resourceFile7594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7595", + "filePath": "resourceFile7595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7596", + "filePath": "resourceFile7596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7597", + "filePath": "resourceFile7597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7598", + "filePath": "resourceFile7598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7599", + "filePath": "resourceFile7599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7600", + "filePath": "resourceFile7600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7601", + "filePath": "resourceFile7601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7602", + "filePath": "resourceFile7602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7603", + "filePath": "resourceFile7603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7604", + "filePath": "resourceFile7604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7605", + "filePath": "resourceFile7605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7606", + "filePath": "resourceFile7606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7607", + "filePath": "resourceFile7607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7608", + "filePath": "resourceFile7608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7609", + "filePath": "resourceFile7609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7610", + "filePath": "resourceFile7610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7611", + "filePath": "resourceFile7611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7612", + "filePath": "resourceFile7612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7613", + "filePath": "resourceFile7613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7614", + "filePath": "resourceFile7614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7615", + "filePath": "resourceFile7615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7616", + "filePath": "resourceFile7616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7617", + "filePath": "resourceFile7617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7618", + "filePath": "resourceFile7618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7619", + "filePath": "resourceFile7619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7620", + "filePath": "resourceFile7620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7621", + "filePath": "resourceFile7621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7622", + "filePath": "resourceFile7622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7623", + "filePath": "resourceFile7623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7624", + "filePath": "resourceFile7624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7625", + "filePath": "resourceFile7625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7626", + "filePath": "resourceFile7626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7627", + "filePath": "resourceFile7627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7628", + "filePath": "resourceFile7628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7629", + "filePath": "resourceFile7629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7630", + "filePath": "resourceFile7630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7631", + "filePath": "resourceFile7631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7632", + "filePath": "resourceFile7632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7633", + "filePath": "resourceFile7633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7634", + "filePath": "resourceFile7634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7635", + "filePath": "resourceFile7635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7636", + "filePath": "resourceFile7636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7637", + "filePath": "resourceFile7637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7638", + "filePath": "resourceFile7638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7639", + "filePath": "resourceFile7639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7640", + "filePath": "resourceFile7640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7641", + "filePath": "resourceFile7641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7642", + "filePath": "resourceFile7642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7643", + "filePath": "resourceFile7643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7644", + "filePath": "resourceFile7644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7645", + "filePath": "resourceFile7645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7646", + "filePath": "resourceFile7646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7647", + "filePath": "resourceFile7647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7648", + "filePath": "resourceFile7648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7649", + "filePath": "resourceFile7649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7650", + "filePath": "resourceFile7650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7651", + "filePath": "resourceFile7651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7652", + "filePath": "resourceFile7652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7653", + "filePath": "resourceFile7653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7654", + "filePath": "resourceFile7654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7655", + "filePath": "resourceFile7655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7656", + "filePath": "resourceFile7656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7657", + "filePath": "resourceFile7657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7658", + "filePath": "resourceFile7658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7659", + "filePath": "resourceFile7659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7660", + "filePath": "resourceFile7660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7661", + "filePath": "resourceFile7661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7662", + "filePath": "resourceFile7662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7663", + "filePath": "resourceFile7663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7664", + "filePath": "resourceFile7664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7665", + "filePath": "resourceFile7665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7666", + "filePath": "resourceFile7666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7667", + "filePath": "resourceFile7667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7668", + "filePath": "resourceFile7668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7669", + "filePath": "resourceFile7669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7670", + "filePath": "resourceFile7670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7671", + "filePath": "resourceFile7671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7672", + "filePath": "resourceFile7672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7673", + "filePath": "resourceFile7673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7674", + "filePath": "resourceFile7674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7675", + "filePath": "resourceFile7675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7676", + "filePath": "resourceFile7676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7677", + "filePath": "resourceFile7677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7678", + "filePath": "resourceFile7678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7679", + "filePath": "resourceFile7679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7680", + "filePath": "resourceFile7680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7681", + "filePath": "resourceFile7681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7682", + "filePath": "resourceFile7682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7683", + "filePath": "resourceFile7683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7684", + "filePath": "resourceFile7684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7685", + "filePath": "resourceFile7685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7686", + "filePath": "resourceFile7686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7687", + "filePath": "resourceFile7687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7688", + "filePath": "resourceFile7688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7689", + "filePath": "resourceFile7689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7690", + "filePath": "resourceFile7690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7691", + "filePath": "resourceFile7691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7692", + "filePath": "resourceFile7692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7693", + "filePath": "resourceFile7693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7694", + "filePath": "resourceFile7694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7695", + "filePath": "resourceFile7695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7696", + "filePath": "resourceFile7696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7697", + "filePath": "resourceFile7697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7698", + "filePath": "resourceFile7698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7699", + "filePath": "resourceFile7699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7700", + "filePath": "resourceFile7700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7701", + "filePath": "resourceFile7701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7702", + "filePath": "resourceFile7702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7703", + "filePath": "resourceFile7703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7704", + "filePath": "resourceFile7704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7705", + "filePath": "resourceFile7705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7706", + "filePath": "resourceFile7706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7707", + "filePath": "resourceFile7707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7708", + "filePath": "resourceFile7708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7709", + "filePath": "resourceFile7709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7710", + "filePath": "resourceFile7710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7711", + "filePath": "resourceFile7711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7712", + "filePath": "resourceFile7712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7713", + "filePath": "resourceFile7713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7714", + "filePath": "resourceFile7714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7715", + "filePath": "resourceFile7715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7716", + "filePath": "resourceFile7716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7717", + "filePath": "resourceFile7717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7718", + "filePath": "resourceFile7718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7719", + "filePath": "resourceFile7719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7720", + "filePath": "resourceFile7720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7721", + "filePath": "resourceFile7721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7722", + "filePath": "resourceFile7722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7723", + "filePath": "resourceFile7723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7724", + "filePath": "resourceFile7724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7725", + "filePath": "resourceFile7725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7726", + "filePath": "resourceFile7726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7727", + "filePath": "resourceFile7727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7728", + "filePath": "resourceFile7728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7729", + "filePath": "resourceFile7729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7730", + "filePath": "resourceFile7730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7731", + "filePath": "resourceFile7731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7732", + "filePath": "resourceFile7732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7733", + "filePath": "resourceFile7733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7734", + "filePath": "resourceFile7734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7735", + "filePath": "resourceFile7735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7736", + "filePath": "resourceFile7736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7737", + "filePath": "resourceFile7737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7738", + "filePath": "resourceFile7738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7739", + "filePath": "resourceFile7739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7740", + "filePath": "resourceFile7740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7741", + "filePath": "resourceFile7741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7742", + "filePath": "resourceFile7742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7743", + "filePath": "resourceFile7743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7744", + "filePath": "resourceFile7744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7745", + "filePath": "resourceFile7745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7746", + "filePath": "resourceFile7746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7747", + "filePath": "resourceFile7747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7748", + "filePath": "resourceFile7748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7749", + "filePath": "resourceFile7749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7750", + "filePath": "resourceFile7750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7751", + "filePath": "resourceFile7751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7752", + "filePath": "resourceFile7752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7753", + "filePath": "resourceFile7753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7754", + "filePath": "resourceFile7754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7755", + "filePath": "resourceFile7755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7756", + "filePath": "resourceFile7756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7757", + "filePath": "resourceFile7757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7758", + "filePath": "resourceFile7758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7759", + "filePath": "resourceFile7759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7760", + "filePath": "resourceFile7760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7761", + "filePath": "resourceFile7761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7762", + "filePath": "resourceFile7762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7763", + "filePath": "resourceFile7763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7764", + "filePath": "resourceFile7764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7765", + "filePath": "resourceFile7765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7766", + "filePath": "resourceFile7766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7767", + "filePath": "resourceFile7767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7768", + "filePath": "resourceFile7768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7769", + "filePath": "resourceFile7769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7770", + "filePath": "resourceFile7770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7771", + "filePath": "resourceFile7771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7772", + "filePath": "resourceFile7772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7773", + "filePath": "resourceFile7773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7774", + "filePath": "resourceFile7774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7775", + "filePath": "resourceFile7775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7776", + "filePath": "resourceFile7776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7777", + "filePath": "resourceFile7777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7778", + "filePath": "resourceFile7778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7779", + "filePath": "resourceFile7779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7780", + "filePath": "resourceFile7780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7781", + "filePath": "resourceFile7781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7782", + "filePath": "resourceFile7782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7783", + "filePath": "resourceFile7783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7784", + "filePath": "resourceFile7784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7785", + "filePath": "resourceFile7785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7786", + "filePath": "resourceFile7786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7787", + "filePath": "resourceFile7787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7788", + "filePath": "resourceFile7788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7789", + "filePath": "resourceFile7789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7790", + "filePath": "resourceFile7790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7791", + "filePath": "resourceFile7791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7792", + "filePath": "resourceFile7792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7793", + "filePath": "resourceFile7793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7794", + "filePath": "resourceFile7794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7795", + "filePath": "resourceFile7795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7796", + "filePath": "resourceFile7796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7797", + "filePath": "resourceFile7797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7798", + "filePath": "resourceFile7798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7799", + "filePath": "resourceFile7799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7800", + "filePath": "resourceFile7800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7801", + "filePath": "resourceFile7801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7802", + "filePath": "resourceFile7802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7803", + "filePath": "resourceFile7803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7804", + "filePath": "resourceFile7804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7805", + "filePath": "resourceFile7805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7806", + "filePath": "resourceFile7806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7807", + "filePath": "resourceFile7807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7808", + "filePath": "resourceFile7808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7809", + "filePath": "resourceFile7809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7810", + "filePath": "resourceFile7810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7811", + "filePath": "resourceFile7811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7812", + "filePath": "resourceFile7812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7813", + "filePath": "resourceFile7813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7814", + "filePath": "resourceFile7814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7815", + "filePath": "resourceFile7815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7816", + "filePath": "resourceFile7816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7817", + "filePath": "resourceFile7817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7818", + "filePath": "resourceFile7818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7819", + "filePath": "resourceFile7819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7820", + "filePath": "resourceFile7820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7821", + "filePath": "resourceFile7821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7822", + "filePath": "resourceFile7822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7823", + "filePath": "resourceFile7823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7824", + "filePath": "resourceFile7824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7825", + "filePath": "resourceFile7825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7826", + "filePath": "resourceFile7826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7827", + "filePath": "resourceFile7827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7828", + "filePath": "resourceFile7828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7829", + "filePath": "resourceFile7829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7830", + "filePath": "resourceFile7830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7831", + "filePath": "resourceFile7831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7832", + "filePath": "resourceFile7832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7833", + "filePath": "resourceFile7833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7834", + "filePath": "resourceFile7834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7835", + "filePath": "resourceFile7835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7836", + "filePath": "resourceFile7836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7837", + "filePath": "resourceFile7837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7838", + "filePath": "resourceFile7838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7839", + "filePath": "resourceFile7839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7840", + "filePath": "resourceFile7840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7841", + "filePath": "resourceFile7841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7842", + "filePath": "resourceFile7842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7843", + "filePath": "resourceFile7843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7844", + "filePath": "resourceFile7844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7845", + "filePath": "resourceFile7845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7846", + "filePath": "resourceFile7846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7847", + "filePath": "resourceFile7847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7848", + "filePath": "resourceFile7848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7849", + "filePath": "resourceFile7849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7850", + "filePath": "resourceFile7850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7851", + "filePath": "resourceFile7851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7852", + "filePath": "resourceFile7852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7853", + "filePath": "resourceFile7853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7854", + "filePath": "resourceFile7854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7855", + "filePath": "resourceFile7855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7856", + "filePath": "resourceFile7856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7857", + "filePath": "resourceFile7857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7858", + "filePath": "resourceFile7858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7859", + "filePath": "resourceFile7859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7860", + "filePath": "resourceFile7860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7861", + "filePath": "resourceFile7861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7862", + "filePath": "resourceFile7862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7863", + "filePath": "resourceFile7863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7864", + "filePath": "resourceFile7864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7865", + "filePath": "resourceFile7865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7866", + "filePath": "resourceFile7866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7867", + "filePath": "resourceFile7867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7868", + "filePath": "resourceFile7868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7869", + "filePath": "resourceFile7869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7870", + "filePath": "resourceFile7870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7871", + "filePath": "resourceFile7871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7872", + "filePath": "resourceFile7872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7873", + "filePath": "resourceFile7873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7874", + "filePath": "resourceFile7874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7875", + "filePath": "resourceFile7875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7876", + "filePath": "resourceFile7876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7877", + "filePath": "resourceFile7877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7878", + "filePath": "resourceFile7878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7879", + "filePath": "resourceFile7879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7880", + "filePath": "resourceFile7880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7881", + "filePath": "resourceFile7881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7882", + "filePath": "resourceFile7882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7883", + "filePath": "resourceFile7883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7884", + "filePath": "resourceFile7884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7885", + "filePath": "resourceFile7885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7886", + "filePath": "resourceFile7886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7887", + "filePath": "resourceFile7887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7888", + "filePath": "resourceFile7888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7889", + "filePath": "resourceFile7889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7890", + "filePath": "resourceFile7890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7891", + "filePath": "resourceFile7891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7892", + "filePath": "resourceFile7892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7893", + "filePath": "resourceFile7893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7894", + "filePath": "resourceFile7894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7895", + "filePath": "resourceFile7895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7896", + "filePath": "resourceFile7896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7897", + "filePath": "resourceFile7897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7898", + "filePath": "resourceFile7898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7899", + "filePath": "resourceFile7899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7900", + "filePath": "resourceFile7900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7901", + "filePath": "resourceFile7901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7902", + "filePath": "resourceFile7902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7903", + "filePath": "resourceFile7903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7904", + "filePath": "resourceFile7904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7905", + "filePath": "resourceFile7905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7906", + "filePath": "resourceFile7906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7907", + "filePath": "resourceFile7907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7908", + "filePath": "resourceFile7908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7909", + "filePath": "resourceFile7909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7910", + "filePath": "resourceFile7910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7911", + "filePath": "resourceFile7911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7912", + "filePath": "resourceFile7912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7913", + "filePath": "resourceFile7913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7914", + "filePath": "resourceFile7914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7915", + "filePath": "resourceFile7915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7916", + "filePath": "resourceFile7916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7917", + "filePath": "resourceFile7917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7918", + "filePath": "resourceFile7918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7919", + "filePath": "resourceFile7919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7920", + "filePath": "resourceFile7920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7921", + "filePath": "resourceFile7921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7922", + "filePath": "resourceFile7922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7923", + "filePath": "resourceFile7923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7924", + "filePath": "resourceFile7924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7925", + "filePath": "resourceFile7925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7926", + "filePath": "resourceFile7926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7927", + "filePath": "resourceFile7927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7928", + "filePath": "resourceFile7928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7929", + "filePath": "resourceFile7929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7930", + "filePath": "resourceFile7930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7931", + "filePath": "resourceFile7931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7932", + "filePath": "resourceFile7932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7933", + "filePath": "resourceFile7933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7934", + "filePath": "resourceFile7934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7935", + "filePath": "resourceFile7935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7936", + "filePath": "resourceFile7936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7937", + "filePath": "resourceFile7937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7938", + "filePath": "resourceFile7938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7939", + "filePath": "resourceFile7939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7940", + "filePath": "resourceFile7940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7941", + "filePath": "resourceFile7941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7942", + "filePath": "resourceFile7942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7943", + "filePath": "resourceFile7943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7944", + "filePath": "resourceFile7944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7945", + "filePath": "resourceFile7945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7946", + "filePath": "resourceFile7946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7947", + "filePath": "resourceFile7947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7948", + "filePath": "resourceFile7948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7949", + "filePath": "resourceFile7949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7950", + "filePath": "resourceFile7950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7951", + "filePath": "resourceFile7951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7952", + "filePath": "resourceFile7952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7953", + "filePath": "resourceFile7953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7954", + "filePath": "resourceFile7954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7955", + "filePath": "resourceFile7955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7956", + "filePath": "resourceFile7956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7957", + "filePath": "resourceFile7957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7958", + "filePath": "resourceFile7958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7959", + "filePath": "resourceFile7959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7960", + "filePath": "resourceFile7960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7961", + "filePath": "resourceFile7961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7962", + "filePath": "resourceFile7962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7963", + "filePath": "resourceFile7963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7964", + "filePath": "resourceFile7964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7965", + "filePath": "resourceFile7965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7966", + "filePath": "resourceFile7966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7967", + "filePath": "resourceFile7967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7968", + "filePath": "resourceFile7968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7969", + "filePath": "resourceFile7969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7970", + "filePath": "resourceFile7970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7971", + "filePath": "resourceFile7971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7972", + "filePath": "resourceFile7972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7973", + "filePath": "resourceFile7973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7974", + "filePath": "resourceFile7974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7975", + "filePath": "resourceFile7975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7976", + "filePath": "resourceFile7976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7977", + "filePath": "resourceFile7977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7978", + "filePath": "resourceFile7978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7979", + "filePath": "resourceFile7979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7980", + "filePath": "resourceFile7980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7981", + "filePath": "resourceFile7981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7982", + "filePath": "resourceFile7982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7983", + "filePath": "resourceFile7983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7984", + "filePath": "resourceFile7984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7985", + "filePath": "resourceFile7985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7986", + "filePath": "resourceFile7986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7987", + "filePath": "resourceFile7987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7988", + "filePath": "resourceFile7988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7989", + "filePath": "resourceFile7989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7990", + "filePath": "resourceFile7990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7991", + "filePath": "resourceFile7991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7992", + "filePath": "resourceFile7992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7993", + "filePath": "resourceFile7993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7994", + "filePath": "resourceFile7994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7995", + "filePath": "resourceFile7995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7996", + "filePath": "resourceFile7996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7997", + "filePath": "resourceFile7997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7998", + "filePath": "resourceFile7998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7999", + "filePath": "resourceFile7999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8000", + "filePath": "resourceFile8000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8001", + "filePath": "resourceFile8001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8002", + "filePath": "resourceFile8002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8003", + "filePath": "resourceFile8003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8004", + "filePath": "resourceFile8004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8005", + "filePath": "resourceFile8005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8006", + "filePath": "resourceFile8006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8007", + "filePath": "resourceFile8007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8008", + "filePath": "resourceFile8008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8009", + "filePath": "resourceFile8009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8010", + "filePath": "resourceFile8010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8011", + "filePath": "resourceFile8011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8012", + "filePath": "resourceFile8012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8013", + "filePath": "resourceFile8013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8014", + "filePath": "resourceFile8014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8015", + "filePath": "resourceFile8015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8016", + "filePath": "resourceFile8016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8017", + "filePath": "resourceFile8017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8018", + "filePath": "resourceFile8018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8019", + "filePath": "resourceFile8019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8020", + "filePath": "resourceFile8020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8021", + "filePath": "resourceFile8021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8022", + "filePath": "resourceFile8022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8023", + "filePath": "resourceFile8023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8024", + "filePath": "resourceFile8024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8025", + "filePath": "resourceFile8025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8026", + "filePath": "resourceFile8026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8027", + "filePath": "resourceFile8027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8028", + "filePath": "resourceFile8028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8029", + "filePath": "resourceFile8029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8030", + "filePath": "resourceFile8030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8031", + "filePath": "resourceFile8031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8032", + "filePath": "resourceFile8032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8033", + "filePath": "resourceFile8033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8034", + "filePath": "resourceFile8034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8035", + "filePath": "resourceFile8035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8036", + "filePath": "resourceFile8036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8037", + "filePath": "resourceFile8037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8038", + "filePath": "resourceFile8038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8039", + "filePath": "resourceFile8039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8040", + "filePath": "resourceFile8040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8041", + "filePath": "resourceFile8041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8042", + "filePath": "resourceFile8042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8043", + "filePath": "resourceFile8043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8044", + "filePath": "resourceFile8044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8045", + "filePath": "resourceFile8045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8046", + "filePath": "resourceFile8046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8047", + "filePath": "resourceFile8047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8048", + "filePath": "resourceFile8048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8049", + "filePath": "resourceFile8049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8050", + "filePath": "resourceFile8050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8051", + "filePath": "resourceFile8051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8052", + "filePath": "resourceFile8052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8053", + "filePath": "resourceFile8053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8054", + "filePath": "resourceFile8054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8055", + "filePath": "resourceFile8055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8056", + "filePath": "resourceFile8056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8057", + "filePath": "resourceFile8057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8058", + "filePath": "resourceFile8058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8059", + "filePath": "resourceFile8059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8060", + "filePath": "resourceFile8060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8061", + "filePath": "resourceFile8061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8062", + "filePath": "resourceFile8062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8063", + "filePath": "resourceFile8063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8064", + "filePath": "resourceFile8064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8065", + "filePath": "resourceFile8065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8066", + "filePath": "resourceFile8066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8067", + "filePath": "resourceFile8067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8068", + "filePath": "resourceFile8068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8069", + "filePath": "resourceFile8069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8070", + "filePath": "resourceFile8070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8071", + "filePath": "resourceFile8071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8072", + "filePath": "resourceFile8072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8073", + "filePath": "resourceFile8073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8074", + "filePath": "resourceFile8074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8075", + "filePath": "resourceFile8075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8076", + "filePath": "resourceFile8076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8077", + "filePath": "resourceFile8077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8078", + "filePath": "resourceFile8078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8079", + "filePath": "resourceFile8079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8080", + "filePath": "resourceFile8080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8081", + "filePath": "resourceFile8081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8082", + "filePath": "resourceFile8082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8083", + "filePath": "resourceFile8083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8084", + "filePath": "resourceFile8084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8085", + "filePath": "resourceFile8085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8086", + "filePath": "resourceFile8086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8087", + "filePath": "resourceFile8087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8088", + "filePath": "resourceFile8088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8089", + "filePath": "resourceFile8089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8090", + "filePath": "resourceFile8090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8091", + "filePath": "resourceFile8091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8092", + "filePath": "resourceFile8092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8093", + "filePath": "resourceFile8093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8094", + "filePath": "resourceFile8094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8095", + "filePath": "resourceFile8095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8096", + "filePath": "resourceFile8096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8097", + "filePath": "resourceFile8097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8098", + "filePath": "resourceFile8098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8099", + "filePath": "resourceFile8099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8100", + "filePath": "resourceFile8100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8101", + "filePath": "resourceFile8101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8102", + "filePath": "resourceFile8102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8103", + "filePath": "resourceFile8103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8104", + "filePath": "resourceFile8104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8105", + "filePath": "resourceFile8105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8106", + "filePath": "resourceFile8106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8107", + "filePath": "resourceFile8107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8108", + "filePath": "resourceFile8108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8109", + "filePath": "resourceFile8109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8110", + "filePath": "resourceFile8110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8111", + "filePath": "resourceFile8111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8112", + "filePath": "resourceFile8112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8113", + "filePath": "resourceFile8113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8114", + "filePath": "resourceFile8114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8115", + "filePath": "resourceFile8115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8116", + "filePath": "resourceFile8116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8117", + "filePath": "resourceFile8117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8118", + "filePath": "resourceFile8118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8119", + "filePath": "resourceFile8119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8120", + "filePath": "resourceFile8120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8121", + "filePath": "resourceFile8121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8122", + "filePath": "resourceFile8122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8123", + "filePath": "resourceFile8123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8124", + "filePath": "resourceFile8124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8125", + "filePath": "resourceFile8125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8126", + "filePath": "resourceFile8126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8127", + "filePath": "resourceFile8127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8128", + "filePath": "resourceFile8128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8129", + "filePath": "resourceFile8129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8130", + "filePath": "resourceFile8130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8131", + "filePath": "resourceFile8131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8132", + "filePath": "resourceFile8132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8133", + "filePath": "resourceFile8133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8134", + "filePath": "resourceFile8134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8135", + "filePath": "resourceFile8135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8136", + "filePath": "resourceFile8136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8137", + "filePath": "resourceFile8137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8138", + "filePath": "resourceFile8138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8139", + "filePath": "resourceFile8139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8140", + "filePath": "resourceFile8140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8141", + "filePath": "resourceFile8141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8142", + "filePath": "resourceFile8142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8143", + "filePath": "resourceFile8143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8144", + "filePath": "resourceFile8144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8145", + "filePath": "resourceFile8145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8146", + "filePath": "resourceFile8146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8147", + "filePath": "resourceFile8147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8148", + "filePath": "resourceFile8148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8149", + "filePath": "resourceFile8149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8150", + "filePath": "resourceFile8150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8151", + "filePath": "resourceFile8151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8152", + "filePath": "resourceFile8152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8153", + "filePath": "resourceFile8153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8154", + "filePath": "resourceFile8154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8155", + "filePath": "resourceFile8155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8156", + "filePath": "resourceFile8156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8157", + "filePath": "resourceFile8157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8158", + "filePath": "resourceFile8158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8159", + "filePath": "resourceFile8159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8160", + "filePath": "resourceFile8160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8161", + "filePath": "resourceFile8161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8162", + "filePath": "resourceFile8162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8163", + "filePath": "resourceFile8163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8164", + "filePath": "resourceFile8164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8165", + "filePath": "resourceFile8165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8166", + "filePath": "resourceFile8166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8167", + "filePath": "resourceFile8167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8168", + "filePath": "resourceFile8168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8169", + "filePath": "resourceFile8169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8170", + "filePath": "resourceFile8170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8171", + "filePath": "resourceFile8171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8172", + "filePath": "resourceFile8172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8173", + "filePath": "resourceFile8173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8174", + "filePath": "resourceFile8174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8175", + "filePath": "resourceFile8175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8176", + "filePath": "resourceFile8176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8177", + "filePath": "resourceFile8177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8178", + "filePath": "resourceFile8178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8179", + "filePath": "resourceFile8179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8180", + "filePath": "resourceFile8180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8181", + "filePath": "resourceFile8181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8182", + "filePath": "resourceFile8182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8183", + "filePath": "resourceFile8183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8184", + "filePath": "resourceFile8184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8185", + "filePath": "resourceFile8185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8186", + "filePath": "resourceFile8186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8187", + "filePath": "resourceFile8187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8188", + "filePath": "resourceFile8188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8189", + "filePath": "resourceFile8189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8190", + "filePath": "resourceFile8190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8191", + "filePath": "resourceFile8191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8192", + "filePath": "resourceFile8192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8193", + "filePath": "resourceFile8193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8194", + "filePath": "resourceFile8194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8195", + "filePath": "resourceFile8195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8196", + "filePath": "resourceFile8196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8197", + "filePath": "resourceFile8197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8198", + "filePath": "resourceFile8198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8199", + "filePath": "resourceFile8199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8200", + "filePath": "resourceFile8200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8201", + "filePath": "resourceFile8201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8202", + "filePath": "resourceFile8202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8203", + "filePath": "resourceFile8203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8204", + "filePath": "resourceFile8204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8205", + "filePath": "resourceFile8205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8206", + "filePath": "resourceFile8206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8207", + "filePath": "resourceFile8207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8208", + "filePath": "resourceFile8208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8209", + "filePath": "resourceFile8209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8210", + "filePath": "resourceFile8210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8211", + "filePath": "resourceFile8211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8212", + "filePath": "resourceFile8212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8213", + "filePath": "resourceFile8213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8214", + "filePath": "resourceFile8214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8215", + "filePath": "resourceFile8215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8216", + "filePath": "resourceFile8216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8217", + "filePath": "resourceFile8217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8218", + "filePath": "resourceFile8218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8219", + "filePath": "resourceFile8219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8220", + "filePath": "resourceFile8220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8221", + "filePath": "resourceFile8221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8222", + "filePath": "resourceFile8222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8223", + "filePath": "resourceFile8223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8224", + "filePath": "resourceFile8224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8225", + "filePath": "resourceFile8225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8226", + "filePath": "resourceFile8226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8227", + "filePath": "resourceFile8227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8228", + "filePath": "resourceFile8228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8229", + "filePath": "resourceFile8229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8230", + "filePath": "resourceFile8230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8231", + "filePath": "resourceFile8231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8232", + "filePath": "resourceFile8232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8233", + "filePath": "resourceFile8233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8234", + "filePath": "resourceFile8234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8235", + "filePath": "resourceFile8235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8236", + "filePath": "resourceFile8236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8237", + "filePath": "resourceFile8237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8238", + "filePath": "resourceFile8238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8239", + "filePath": "resourceFile8239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8240", + "filePath": "resourceFile8240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8241", + "filePath": "resourceFile8241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8242", + "filePath": "resourceFile8242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8243", + "filePath": "resourceFile8243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8244", + "filePath": "resourceFile8244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8245", + "filePath": "resourceFile8245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8246", + "filePath": "resourceFile8246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8247", + "filePath": "resourceFile8247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8248", + "filePath": "resourceFile8248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8249", + "filePath": "resourceFile8249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8250", + "filePath": "resourceFile8250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8251", + "filePath": "resourceFile8251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8252", + "filePath": "resourceFile8252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8253", + "filePath": "resourceFile8253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8254", + "filePath": "resourceFile8254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8255", + "filePath": "resourceFile8255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8256", + "filePath": "resourceFile8256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8257", + "filePath": "resourceFile8257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8258", + "filePath": "resourceFile8258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8259", + "filePath": "resourceFile8259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8260", + "filePath": "resourceFile8260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8261", + "filePath": "resourceFile8261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8262", + "filePath": "resourceFile8262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8263", + "filePath": "resourceFile8263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8264", + "filePath": "resourceFile8264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8265", + "filePath": "resourceFile8265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8266", + "filePath": "resourceFile8266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8267", + "filePath": "resourceFile8267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8268", + "filePath": "resourceFile8268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8269", + "filePath": "resourceFile8269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8270", + "filePath": "resourceFile8270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8271", + "filePath": "resourceFile8271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8272", + "filePath": "resourceFile8272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8273", + "filePath": "resourceFile8273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8274", + "filePath": "resourceFile8274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8275", + "filePath": "resourceFile8275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8276", + "filePath": "resourceFile8276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8277", + "filePath": "resourceFile8277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8278", + "filePath": "resourceFile8278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8279", + "filePath": "resourceFile8279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8280", + "filePath": "resourceFile8280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8281", + "filePath": "resourceFile8281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8282", + "filePath": "resourceFile8282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8283", + "filePath": "resourceFile8283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8284", + "filePath": "resourceFile8284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8285", + "filePath": "resourceFile8285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8286", + "filePath": "resourceFile8286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8287", + "filePath": "resourceFile8287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8288", + "filePath": "resourceFile8288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8289", + "filePath": "resourceFile8289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8290", + "filePath": "resourceFile8290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8291", + "filePath": "resourceFile8291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8292", + "filePath": "resourceFile8292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8293", + "filePath": "resourceFile8293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8294", + "filePath": "resourceFile8294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8295", + "filePath": "resourceFile8295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8296", + "filePath": "resourceFile8296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8297", + "filePath": "resourceFile8297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8298", + "filePath": "resourceFile8298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8299", + "filePath": "resourceFile8299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8300", + "filePath": "resourceFile8300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8301", + "filePath": "resourceFile8301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8302", + "filePath": "resourceFile8302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8303", + "filePath": "resourceFile8303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8304", + "filePath": "resourceFile8304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8305", + "filePath": "resourceFile8305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8306", + "filePath": "resourceFile8306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8307", + "filePath": "resourceFile8307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8308", + "filePath": "resourceFile8308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8309", + "filePath": "resourceFile8309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8310", + "filePath": "resourceFile8310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8311", + "filePath": "resourceFile8311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8312", + "filePath": "resourceFile8312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8313", + "filePath": "resourceFile8313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8314", + "filePath": "resourceFile8314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8315", + "filePath": "resourceFile8315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8316", + "filePath": "resourceFile8316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8317", + "filePath": "resourceFile8317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8318", + "filePath": "resourceFile8318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8319", + "filePath": "resourceFile8319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8320", + "filePath": "resourceFile8320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8321", + "filePath": "resourceFile8321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8322", + "filePath": "resourceFile8322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8323", + "filePath": "resourceFile8323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8324", + "filePath": "resourceFile8324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8325", + "filePath": "resourceFile8325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8326", + "filePath": "resourceFile8326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8327", + "filePath": "resourceFile8327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8328", + "filePath": "resourceFile8328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8329", + "filePath": "resourceFile8329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8330", + "filePath": "resourceFile8330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8331", + "filePath": "resourceFile8331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8332", + "filePath": "resourceFile8332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8333", + "filePath": "resourceFile8333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8334", + "filePath": "resourceFile8334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8335", + "filePath": "resourceFile8335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8336", + "filePath": "resourceFile8336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8337", + "filePath": "resourceFile8337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8338", + "filePath": "resourceFile8338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8339", + "filePath": "resourceFile8339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8340", + "filePath": "resourceFile8340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8341", + "filePath": "resourceFile8341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8342", + "filePath": "resourceFile8342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8343", + "filePath": "resourceFile8343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8344", + "filePath": "resourceFile8344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8345", + "filePath": "resourceFile8345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8346", + "filePath": "resourceFile8346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8347", + "filePath": "resourceFile8347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8348", + "filePath": "resourceFile8348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8349", + "filePath": "resourceFile8349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8350", + "filePath": "resourceFile8350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8351", + "filePath": "resourceFile8351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8352", + "filePath": "resourceFile8352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8353", + "filePath": "resourceFile8353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8354", + "filePath": "resourceFile8354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8355", + "filePath": "resourceFile8355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8356", + "filePath": "resourceFile8356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8357", + "filePath": "resourceFile8357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8358", + "filePath": "resourceFile8358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8359", + "filePath": "resourceFile8359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8360", + "filePath": "resourceFile8360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8361", + "filePath": "resourceFile8361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8362", + "filePath": "resourceFile8362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8363", + "filePath": "resourceFile8363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8364", + "filePath": "resourceFile8364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8365", + "filePath": "resourceFile8365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8366", + "filePath": "resourceFile8366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8367", + "filePath": "resourceFile8367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8368", + "filePath": "resourceFile8368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8369", + "filePath": "resourceFile8369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8370", + "filePath": "resourceFile8370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8371", + "filePath": "resourceFile8371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8372", + "filePath": "resourceFile8372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8373", + "filePath": "resourceFile8373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8374", + "filePath": "resourceFile8374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8375", + "filePath": "resourceFile8375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8376", + "filePath": "resourceFile8376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8377", + "filePath": "resourceFile8377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8378", + "filePath": "resourceFile8378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8379", + "filePath": "resourceFile8379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8380", + "filePath": "resourceFile8380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8381", + "filePath": "resourceFile8381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8382", + "filePath": "resourceFile8382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8383", + "filePath": "resourceFile8383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8384", + "filePath": "resourceFile8384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8385", + "filePath": "resourceFile8385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8386", + "filePath": "resourceFile8386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8387", + "filePath": "resourceFile8387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8388", + "filePath": "resourceFile8388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8389", + "filePath": "resourceFile8389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8390", + "filePath": "resourceFile8390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8391", + "filePath": "resourceFile8391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8392", + "filePath": "resourceFile8392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8393", + "filePath": "resourceFile8393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8394", + "filePath": "resourceFile8394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8395", + "filePath": "resourceFile8395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8396", + "filePath": "resourceFile8396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8397", + "filePath": "resourceFile8397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8398", + "filePath": "resourceFile8398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8399", + "filePath": "resourceFile8399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8400", + "filePath": "resourceFile8400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8401", + "filePath": "resourceFile8401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8402", + "filePath": "resourceFile8402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8403", + "filePath": "resourceFile8403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8404", + "filePath": "resourceFile8404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8405", + "filePath": "resourceFile8405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8406", + "filePath": "resourceFile8406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8407", + "filePath": "resourceFile8407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8408", + "filePath": "resourceFile8408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8409", + "filePath": "resourceFile8409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8410", + "filePath": "resourceFile8410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8411", + "filePath": "resourceFile8411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8412", + "filePath": "resourceFile8412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8413", + "filePath": "resourceFile8413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8414", + "filePath": "resourceFile8414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8415", + "filePath": "resourceFile8415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8416", + "filePath": "resourceFile8416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8417", + "filePath": "resourceFile8417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8418", + "filePath": "resourceFile8418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8419", + "filePath": "resourceFile8419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8420", + "filePath": "resourceFile8420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8421", + "filePath": "resourceFile8421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8422", + "filePath": "resourceFile8422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8423", + "filePath": "resourceFile8423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8424", + "filePath": "resourceFile8424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8425", + "filePath": "resourceFile8425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8426", + "filePath": "resourceFile8426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8427", + "filePath": "resourceFile8427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8428", + "filePath": "resourceFile8428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8429", + "filePath": "resourceFile8429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8430", + "filePath": "resourceFile8430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8431", + "filePath": "resourceFile8431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8432", + "filePath": "resourceFile8432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8433", + "filePath": "resourceFile8433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8434", + "filePath": "resourceFile8434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8435", + "filePath": "resourceFile8435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8436", + "filePath": "resourceFile8436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8437", + "filePath": "resourceFile8437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8438", + "filePath": "resourceFile8438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8439", + "filePath": "resourceFile8439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8440", + "filePath": "resourceFile8440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8441", + "filePath": "resourceFile8441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8442", + "filePath": "resourceFile8442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8443", + "filePath": "resourceFile8443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8444", + "filePath": "resourceFile8444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8445", + "filePath": "resourceFile8445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8446", + "filePath": "resourceFile8446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8447", + "filePath": "resourceFile8447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8448", + "filePath": "resourceFile8448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8449", + "filePath": "resourceFile8449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8450", + "filePath": "resourceFile8450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8451", + "filePath": "resourceFile8451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8452", + "filePath": "resourceFile8452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8453", + "filePath": "resourceFile8453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8454", + "filePath": "resourceFile8454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8455", + "filePath": "resourceFile8455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8456", + "filePath": "resourceFile8456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8457", + "filePath": "resourceFile8457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8458", + "filePath": "resourceFile8458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8459", + "filePath": "resourceFile8459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8460", + "filePath": "resourceFile8460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8461", + "filePath": "resourceFile8461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8462", + "filePath": "resourceFile8462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8463", + "filePath": "resourceFile8463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8464", + "filePath": "resourceFile8464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8465", + "filePath": "resourceFile8465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8466", + "filePath": "resourceFile8466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8467", + "filePath": "resourceFile8467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8468", + "filePath": "resourceFile8468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8469", + "filePath": "resourceFile8469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8470", + "filePath": "resourceFile8470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8471", + "filePath": "resourceFile8471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8472", + "filePath": "resourceFile8472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8473", + "filePath": "resourceFile8473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8474", + "filePath": "resourceFile8474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8475", + "filePath": "resourceFile8475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8476", + "filePath": "resourceFile8476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8477", + "filePath": "resourceFile8477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8478", + "filePath": "resourceFile8478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8479", + "filePath": "resourceFile8479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8480", + "filePath": "resourceFile8480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8481", + "filePath": "resourceFile8481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8482", + "filePath": "resourceFile8482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8483", + "filePath": "resourceFile8483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8484", + "filePath": "resourceFile8484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8485", + "filePath": "resourceFile8485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8486", + "filePath": "resourceFile8486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8487", + "filePath": "resourceFile8487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8488", + "filePath": "resourceFile8488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8489", + "filePath": "resourceFile8489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8490", + "filePath": "resourceFile8490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8491", + "filePath": "resourceFile8491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8492", + "filePath": "resourceFile8492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8493", + "filePath": "resourceFile8493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8494", + "filePath": "resourceFile8494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8495", + "filePath": "resourceFile8495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8496", + "filePath": "resourceFile8496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8497", + "filePath": "resourceFile8497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8498", + "filePath": "resourceFile8498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8499", + "filePath": "resourceFile8499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8500", + "filePath": "resourceFile8500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8501", + "filePath": "resourceFile8501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8502", + "filePath": "resourceFile8502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8503", + "filePath": "resourceFile8503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8504", + "filePath": "resourceFile8504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8505", + "filePath": "resourceFile8505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8506", + "filePath": "resourceFile8506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8507", + "filePath": "resourceFile8507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8508", + "filePath": "resourceFile8508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8509", + "filePath": "resourceFile8509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8510", + "filePath": "resourceFile8510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8511", + "filePath": "resourceFile8511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8512", + "filePath": "resourceFile8512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8513", + "filePath": "resourceFile8513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8514", + "filePath": "resourceFile8514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8515", + "filePath": "resourceFile8515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8516", + "filePath": "resourceFile8516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8517", + "filePath": "resourceFile8517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8518", + "filePath": "resourceFile8518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8519", + "filePath": "resourceFile8519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8520", + "filePath": "resourceFile8520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8521", + "filePath": "resourceFile8521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8522", + "filePath": "resourceFile8522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8523", + "filePath": "resourceFile8523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8524", + "filePath": "resourceFile8524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8525", + "filePath": "resourceFile8525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8526", + "filePath": "resourceFile8526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8527", + "filePath": "resourceFile8527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8528", + "filePath": "resourceFile8528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8529", + "filePath": "resourceFile8529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8530", + "filePath": "resourceFile8530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8531", + "filePath": "resourceFile8531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8532", + "filePath": "resourceFile8532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8533", + "filePath": "resourceFile8533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8534", + "filePath": "resourceFile8534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8535", + "filePath": "resourceFile8535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8536", + "filePath": "resourceFile8536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8537", + "filePath": "resourceFile8537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8538", + "filePath": "resourceFile8538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8539", + "filePath": "resourceFile8539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8540", + "filePath": "resourceFile8540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8541", + "filePath": "resourceFile8541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8542", + "filePath": "resourceFile8542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8543", + "filePath": "resourceFile8543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8544", + "filePath": "resourceFile8544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8545", + "filePath": "resourceFile8545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8546", + "filePath": "resourceFile8546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8547", + "filePath": "resourceFile8547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8548", + "filePath": "resourceFile8548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8549", + "filePath": "resourceFile8549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8550", + "filePath": "resourceFile8550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8551", + "filePath": "resourceFile8551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8552", + "filePath": "resourceFile8552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8553", + "filePath": "resourceFile8553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8554", + "filePath": "resourceFile8554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8555", + "filePath": "resourceFile8555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8556", + "filePath": "resourceFile8556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8557", + "filePath": "resourceFile8557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8558", + "filePath": "resourceFile8558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8559", + "filePath": "resourceFile8559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8560", + "filePath": "resourceFile8560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8561", + "filePath": "resourceFile8561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8562", + "filePath": "resourceFile8562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8563", + "filePath": "resourceFile8563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8564", + "filePath": "resourceFile8564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8565", + "filePath": "resourceFile8565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8566", + "filePath": "resourceFile8566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8567", + "filePath": "resourceFile8567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8568", + "filePath": "resourceFile8568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8569", + "filePath": "resourceFile8569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8570", + "filePath": "resourceFile8570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8571", + "filePath": "resourceFile8571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8572", + "filePath": "resourceFile8572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8573", + "filePath": "resourceFile8573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8574", + "filePath": "resourceFile8574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8575", + "filePath": "resourceFile8575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8576", + "filePath": "resourceFile8576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8577", + "filePath": "resourceFile8577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8578", + "filePath": "resourceFile8578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8579", + "filePath": "resourceFile8579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8580", + "filePath": "resourceFile8580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8581", + "filePath": "resourceFile8581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8582", + "filePath": "resourceFile8582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8583", + "filePath": "resourceFile8583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8584", + "filePath": "resourceFile8584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8585", + "filePath": "resourceFile8585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8586", + "filePath": "resourceFile8586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8587", + "filePath": "resourceFile8587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8588", + "filePath": "resourceFile8588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8589", + "filePath": "resourceFile8589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8590", + "filePath": "resourceFile8590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8591", + "filePath": "resourceFile8591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8592", + "filePath": "resourceFile8592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8593", + "filePath": "resourceFile8593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8594", + "filePath": "resourceFile8594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8595", + "filePath": "resourceFile8595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8596", + "filePath": "resourceFile8596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8597", + "filePath": "resourceFile8597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8598", + "filePath": "resourceFile8598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8599", + "filePath": "resourceFile8599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8600", + "filePath": "resourceFile8600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8601", + "filePath": "resourceFile8601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8602", + "filePath": "resourceFile8602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8603", + "filePath": "resourceFile8603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8604", + "filePath": "resourceFile8604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8605", + "filePath": "resourceFile8605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8606", + "filePath": "resourceFile8606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8607", + "filePath": "resourceFile8607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8608", + "filePath": "resourceFile8608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8609", + "filePath": "resourceFile8609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8610", + "filePath": "resourceFile8610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8611", + "filePath": "resourceFile8611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8612", + "filePath": "resourceFile8612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8613", + "filePath": "resourceFile8613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8614", + "filePath": "resourceFile8614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8615", + "filePath": "resourceFile8615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8616", + "filePath": "resourceFile8616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8617", + "filePath": "resourceFile8617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8618", + "filePath": "resourceFile8618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8619", + "filePath": "resourceFile8619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8620", + "filePath": "resourceFile8620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8621", + "filePath": "resourceFile8621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8622", + "filePath": "resourceFile8622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8623", + "filePath": "resourceFile8623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8624", + "filePath": "resourceFile8624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8625", + "filePath": "resourceFile8625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8626", + "filePath": "resourceFile8626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8627", + "filePath": "resourceFile8627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8628", + "filePath": "resourceFile8628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8629", + "filePath": "resourceFile8629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8630", + "filePath": "resourceFile8630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8631", + "filePath": "resourceFile8631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8632", + "filePath": "resourceFile8632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8633", + "filePath": "resourceFile8633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8634", + "filePath": "resourceFile8634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8635", + "filePath": "resourceFile8635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8636", + "filePath": "resourceFile8636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8637", + "filePath": "resourceFile8637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8638", + "filePath": "resourceFile8638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8639", + "filePath": "resourceFile8639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8640", + "filePath": "resourceFile8640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8641", + "filePath": "resourceFile8641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8642", + "filePath": "resourceFile8642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8643", + "filePath": "resourceFile8643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8644", + "filePath": "resourceFile8644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8645", + "filePath": "resourceFile8645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8646", + "filePath": "resourceFile8646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8647", + "filePath": "resourceFile8647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8648", + "filePath": "resourceFile8648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8649", + "filePath": "resourceFile8649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8650", + "filePath": "resourceFile8650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8651", + "filePath": "resourceFile8651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8652", + "filePath": "resourceFile8652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8653", + "filePath": "resourceFile8653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8654", + "filePath": "resourceFile8654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8655", + "filePath": "resourceFile8655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8656", + "filePath": "resourceFile8656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8657", + "filePath": "resourceFile8657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8658", + "filePath": "resourceFile8658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8659", + "filePath": "resourceFile8659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8660", + "filePath": "resourceFile8660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8661", + "filePath": "resourceFile8661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8662", + "filePath": "resourceFile8662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8663", + "filePath": "resourceFile8663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8664", + "filePath": "resourceFile8664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8665", + "filePath": "resourceFile8665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8666", + "filePath": "resourceFile8666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8667", + "filePath": "resourceFile8667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8668", + "filePath": "resourceFile8668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8669", + "filePath": "resourceFile8669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8670", + "filePath": "resourceFile8670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8671", + "filePath": "resourceFile8671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8672", + "filePath": "resourceFile8672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8673", + "filePath": "resourceFile8673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8674", + "filePath": "resourceFile8674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8675", + "filePath": "resourceFile8675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8676", + "filePath": "resourceFile8676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8677", + "filePath": "resourceFile8677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8678", + "filePath": "resourceFile8678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8679", + "filePath": "resourceFile8679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8680", + "filePath": "resourceFile8680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8681", + "filePath": "resourceFile8681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8682", + "filePath": "resourceFile8682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8683", + "filePath": "resourceFile8683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8684", + "filePath": "resourceFile8684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8685", + "filePath": "resourceFile8685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8686", + "filePath": "resourceFile8686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8687", + "filePath": "resourceFile8687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8688", + "filePath": "resourceFile8688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8689", + "filePath": "resourceFile8689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8690", + "filePath": "resourceFile8690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8691", + "filePath": "resourceFile8691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8692", + "filePath": "resourceFile8692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8693", + "filePath": "resourceFile8693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8694", + "filePath": "resourceFile8694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8695", + "filePath": "resourceFile8695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8696", + "filePath": "resourceFile8696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8697", + "filePath": "resourceFile8697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8698", + "filePath": "resourceFile8698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8699", + "filePath": "resourceFile8699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8700", + "filePath": "resourceFile8700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8701", + "filePath": "resourceFile8701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8702", + "filePath": "resourceFile8702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8703", + "filePath": "resourceFile8703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8704", + "filePath": "resourceFile8704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8705", + "filePath": "resourceFile8705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8706", + "filePath": "resourceFile8706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8707", + "filePath": "resourceFile8707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8708", + "filePath": "resourceFile8708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8709", + "filePath": "resourceFile8709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8710", + "filePath": "resourceFile8710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8711", + "filePath": "resourceFile8711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8712", + "filePath": "resourceFile8712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8713", + "filePath": "resourceFile8713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8714", + "filePath": "resourceFile8714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8715", + "filePath": "resourceFile8715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8716", + "filePath": "resourceFile8716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8717", + "filePath": "resourceFile8717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8718", + "filePath": "resourceFile8718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8719", + "filePath": "resourceFile8719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8720", + "filePath": "resourceFile8720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8721", + "filePath": "resourceFile8721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8722", + "filePath": "resourceFile8722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8723", + "filePath": "resourceFile8723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8724", + "filePath": "resourceFile8724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8725", + "filePath": "resourceFile8725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8726", + "filePath": "resourceFile8726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8727", + "filePath": "resourceFile8727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8728", + "filePath": "resourceFile8728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8729", + "filePath": "resourceFile8729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8730", + "filePath": "resourceFile8730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8731", + "filePath": "resourceFile8731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8732", + "filePath": "resourceFile8732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8733", + "filePath": "resourceFile8733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8734", + "filePath": "resourceFile8734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8735", + "filePath": "resourceFile8735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8736", + "filePath": "resourceFile8736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8737", + "filePath": "resourceFile8737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8738", + "filePath": "resourceFile8738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8739", + "filePath": "resourceFile8739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8740", + "filePath": "resourceFile8740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8741", + "filePath": "resourceFile8741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8742", + "filePath": "resourceFile8742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8743", + "filePath": "resourceFile8743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8744", + "filePath": "resourceFile8744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8745", + "filePath": "resourceFile8745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8746", + "filePath": "resourceFile8746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8747", + "filePath": "resourceFile8747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8748", + "filePath": "resourceFile8748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8749", + "filePath": "resourceFile8749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8750", + "filePath": "resourceFile8750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8751", + "filePath": "resourceFile8751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8752", + "filePath": "resourceFile8752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8753", + "filePath": "resourceFile8753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8754", + "filePath": "resourceFile8754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8755", + "filePath": "resourceFile8755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8756", + "filePath": "resourceFile8756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8757", + "filePath": "resourceFile8757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8758", + "filePath": "resourceFile8758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8759", + "filePath": "resourceFile8759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8760", + "filePath": "resourceFile8760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8761", + "filePath": "resourceFile8761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8762", + "filePath": "resourceFile8762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8763", + "filePath": "resourceFile8763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8764", + "filePath": "resourceFile8764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8765", + "filePath": "resourceFile8765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8766", + "filePath": "resourceFile8766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8767", + "filePath": "resourceFile8767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8768", + "filePath": "resourceFile8768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8769", + "filePath": "resourceFile8769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8770", + "filePath": "resourceFile8770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8771", + "filePath": "resourceFile8771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8772", + "filePath": "resourceFile8772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8773", + "filePath": "resourceFile8773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8774", + "filePath": "resourceFile8774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8775", + "filePath": "resourceFile8775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8776", + "filePath": "resourceFile8776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8777", + "filePath": "resourceFile8777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8778", + "filePath": "resourceFile8778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8779", + "filePath": "resourceFile8779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8780", + "filePath": "resourceFile8780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8781", + "filePath": "resourceFile8781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8782", + "filePath": "resourceFile8782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8783", + "filePath": "resourceFile8783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8784", + "filePath": "resourceFile8784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8785", + "filePath": "resourceFile8785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8786", + "filePath": "resourceFile8786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8787", + "filePath": "resourceFile8787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8788", + "filePath": "resourceFile8788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8789", + "filePath": "resourceFile8789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8790", + "filePath": "resourceFile8790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8791", + "filePath": "resourceFile8791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8792", + "filePath": "resourceFile8792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8793", + "filePath": "resourceFile8793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8794", + "filePath": "resourceFile8794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8795", + "filePath": "resourceFile8795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8796", + "filePath": "resourceFile8796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8797", + "filePath": "resourceFile8797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8798", + "filePath": "resourceFile8798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8799", + "filePath": "resourceFile8799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8800", + "filePath": "resourceFile8800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8801", + "filePath": "resourceFile8801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8802", + "filePath": "resourceFile8802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8803", + "filePath": "resourceFile8803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8804", + "filePath": "resourceFile8804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8805", + "filePath": "resourceFile8805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8806", + "filePath": "resourceFile8806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8807", + "filePath": "resourceFile8807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8808", + "filePath": "resourceFile8808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8809", + "filePath": "resourceFile8809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8810", + "filePath": "resourceFile8810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8811", + "filePath": "resourceFile8811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8812", + "filePath": "resourceFile8812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8813", + "filePath": "resourceFile8813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8814", + "filePath": "resourceFile8814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8815", + "filePath": "resourceFile8815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8816", + "filePath": "resourceFile8816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8817", + "filePath": "resourceFile8817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8818", + "filePath": "resourceFile8818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8819", + "filePath": "resourceFile8819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8820", + "filePath": "resourceFile8820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8821", + "filePath": "resourceFile8821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8822", + "filePath": "resourceFile8822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8823", + "filePath": "resourceFile8823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8824", + "filePath": "resourceFile8824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8825", + "filePath": "resourceFile8825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8826", + "filePath": "resourceFile8826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8827", + "filePath": "resourceFile8827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8828", + "filePath": "resourceFile8828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8829", + "filePath": "resourceFile8829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8830", + "filePath": "resourceFile8830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8831", + "filePath": "resourceFile8831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8832", + "filePath": "resourceFile8832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8833", + "filePath": "resourceFile8833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8834", + "filePath": "resourceFile8834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8835", + "filePath": "resourceFile8835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8836", + "filePath": "resourceFile8836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8837", + "filePath": "resourceFile8837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8838", + "filePath": "resourceFile8838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8839", + "filePath": "resourceFile8839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8840", + "filePath": "resourceFile8840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8841", + "filePath": "resourceFile8841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8842", + "filePath": "resourceFile8842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8843", + "filePath": "resourceFile8843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8844", + "filePath": "resourceFile8844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8845", + "filePath": "resourceFile8845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8846", + "filePath": "resourceFile8846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8847", + "filePath": "resourceFile8847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8848", + "filePath": "resourceFile8848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8849", + "filePath": "resourceFile8849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8850", + "filePath": "resourceFile8850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8851", + "filePath": "resourceFile8851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8852", + "filePath": "resourceFile8852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8853", + "filePath": "resourceFile8853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8854", + "filePath": "resourceFile8854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8855", + "filePath": "resourceFile8855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8856", + "filePath": "resourceFile8856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8857", + "filePath": "resourceFile8857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8858", + "filePath": "resourceFile8858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8859", + "filePath": "resourceFile8859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8860", + "filePath": "resourceFile8860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8861", + "filePath": "resourceFile8861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8862", + "filePath": "resourceFile8862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8863", + "filePath": "resourceFile8863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8864", + "filePath": "resourceFile8864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8865", + "filePath": "resourceFile8865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8866", + "filePath": "resourceFile8866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8867", + "filePath": "resourceFile8867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8868", + "filePath": "resourceFile8868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8869", + "filePath": "resourceFile8869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8870", + "filePath": "resourceFile8870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8871", + "filePath": "resourceFile8871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8872", + "filePath": "resourceFile8872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8873", + "filePath": "resourceFile8873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8874", + "filePath": "resourceFile8874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8875", + "filePath": "resourceFile8875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8876", + "filePath": "resourceFile8876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8877", + "filePath": "resourceFile8877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8878", + "filePath": "resourceFile8878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8879", + "filePath": "resourceFile8879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8880", + "filePath": "resourceFile8880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8881", + "filePath": "resourceFile8881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8882", + "filePath": "resourceFile8882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8883", + "filePath": "resourceFile8883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8884", + "filePath": "resourceFile8884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8885", + "filePath": "resourceFile8885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8886", + "filePath": "resourceFile8886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8887", + "filePath": "resourceFile8887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8888", + "filePath": "resourceFile8888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8889", + "filePath": "resourceFile8889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8890", + "filePath": "resourceFile8890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8891", + "filePath": "resourceFile8891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8892", + "filePath": "resourceFile8892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8893", + "filePath": "resourceFile8893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8894", + "filePath": "resourceFile8894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8895", + "filePath": "resourceFile8895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8896", + "filePath": "resourceFile8896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8897", + "filePath": "resourceFile8897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8898", + "filePath": "resourceFile8898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8899", + "filePath": "resourceFile8899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8900", + "filePath": "resourceFile8900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8901", + "filePath": "resourceFile8901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8902", + "filePath": "resourceFile8902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8903", + "filePath": "resourceFile8903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8904", + "filePath": "resourceFile8904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8905", + "filePath": "resourceFile8905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8906", + "filePath": "resourceFile8906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8907", + "filePath": "resourceFile8907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8908", + "filePath": "resourceFile8908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8909", + "filePath": "resourceFile8909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8910", + "filePath": "resourceFile8910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8911", + "filePath": "resourceFile8911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8912", + "filePath": "resourceFile8912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8913", + "filePath": "resourceFile8913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8914", + "filePath": "resourceFile8914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8915", + "filePath": "resourceFile8915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8916", + "filePath": "resourceFile8916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8917", + "filePath": "resourceFile8917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8918", + "filePath": "resourceFile8918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8919", + "filePath": "resourceFile8919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8920", + "filePath": "resourceFile8920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8921", + "filePath": "resourceFile8921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8922", + "filePath": "resourceFile8922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8923", + "filePath": "resourceFile8923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8924", + "filePath": "resourceFile8924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8925", + "filePath": "resourceFile8925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8926", + "filePath": "resourceFile8926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8927", + "filePath": "resourceFile8927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8928", + "filePath": "resourceFile8928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8929", + "filePath": "resourceFile8929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8930", + "filePath": "resourceFile8930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8931", + "filePath": "resourceFile8931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8932", + "filePath": "resourceFile8932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8933", + "filePath": "resourceFile8933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8934", + "filePath": "resourceFile8934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8935", + "filePath": "resourceFile8935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8936", + "filePath": "resourceFile8936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8937", + "filePath": "resourceFile8937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8938", + "filePath": "resourceFile8938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8939", + "filePath": "resourceFile8939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8940", + "filePath": "resourceFile8940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8941", + "filePath": "resourceFile8941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8942", + "filePath": "resourceFile8942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8943", + "filePath": "resourceFile8943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8944", + "filePath": "resourceFile8944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8945", + "filePath": "resourceFile8945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8946", + "filePath": "resourceFile8946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8947", + "filePath": "resourceFile8947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8948", + "filePath": "resourceFile8948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8949", + "filePath": "resourceFile8949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8950", + "filePath": "resourceFile8950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8951", + "filePath": "resourceFile8951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8952", + "filePath": "resourceFile8952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8953", + "filePath": "resourceFile8953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8954", + "filePath": "resourceFile8954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8955", + "filePath": "resourceFile8955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8956", + "filePath": "resourceFile8956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8957", + "filePath": "resourceFile8957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8958", + "filePath": "resourceFile8958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8959", + "filePath": "resourceFile8959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8960", + "filePath": "resourceFile8960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8961", + "filePath": "resourceFile8961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8962", + "filePath": "resourceFile8962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8963", + "filePath": "resourceFile8963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8964", + "filePath": "resourceFile8964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8965", + "filePath": "resourceFile8965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8966", + "filePath": "resourceFile8966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8967", + "filePath": "resourceFile8967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8968", + "filePath": "resourceFile8968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8969", + "filePath": "resourceFile8969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8970", + "filePath": "resourceFile8970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8971", + "filePath": "resourceFile8971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8972", + "filePath": "resourceFile8972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8973", + "filePath": "resourceFile8973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8974", + "filePath": "resourceFile8974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8975", + "filePath": "resourceFile8975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8976", + "filePath": "resourceFile8976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8977", + "filePath": "resourceFile8977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8978", + "filePath": "resourceFile8978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8979", + "filePath": "resourceFile8979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8980", + "filePath": "resourceFile8980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8981", + "filePath": "resourceFile8981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8982", + "filePath": "resourceFile8982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8983", + "filePath": "resourceFile8983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8984", + "filePath": "resourceFile8984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8985", + "filePath": "resourceFile8985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8986", + "filePath": "resourceFile8986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8987", + "filePath": "resourceFile8987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8988", + "filePath": "resourceFile8988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8989", + "filePath": "resourceFile8989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8990", + "filePath": "resourceFile8990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8991", + "filePath": "resourceFile8991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8992", + "filePath": "resourceFile8992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8993", + "filePath": "resourceFile8993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8994", + "filePath": "resourceFile8994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8995", + "filePath": "resourceFile8995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8996", + "filePath": "resourceFile8996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8997", + "filePath": "resourceFile8997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8998", + "filePath": "resourceFile8998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8999", + "filePath": "resourceFile8999"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9000", + "filePath": "resourceFile9000"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9001", + "filePath": "resourceFile9001"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9002", + "filePath": "resourceFile9002"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9003", + "filePath": "resourceFile9003"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9004", + "filePath": "resourceFile9004"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9005", + "filePath": "resourceFile9005"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9006", + "filePath": "resourceFile9006"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9007", + "filePath": "resourceFile9007"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9008", + "filePath": "resourceFile9008"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9009", + "filePath": "resourceFile9009"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9010", + "filePath": "resourceFile9010"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9011", + "filePath": "resourceFile9011"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9012", + "filePath": "resourceFile9012"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9013", + "filePath": "resourceFile9013"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9014", + "filePath": "resourceFile9014"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9015", + "filePath": "resourceFile9015"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9016", + "filePath": "resourceFile9016"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9017", + "filePath": "resourceFile9017"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9018", + "filePath": "resourceFile9018"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9019", + "filePath": "resourceFile9019"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9020", + "filePath": "resourceFile9020"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9021", + "filePath": "resourceFile9021"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9022", + "filePath": "resourceFile9022"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9023", + "filePath": "resourceFile9023"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9024", + "filePath": "resourceFile9024"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9025", + "filePath": "resourceFile9025"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9026", + "filePath": "resourceFile9026"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9027", + "filePath": "resourceFile9027"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9028", + "filePath": "resourceFile9028"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9029", + "filePath": "resourceFile9029"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9030", + "filePath": "resourceFile9030"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9031", + "filePath": "resourceFile9031"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9032", + "filePath": "resourceFile9032"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9033", + "filePath": "resourceFile9033"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9034", + "filePath": "resourceFile9034"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9035", + "filePath": "resourceFile9035"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9036", + "filePath": "resourceFile9036"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9037", + "filePath": "resourceFile9037"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9038", + "filePath": "resourceFile9038"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9039", + "filePath": "resourceFile9039"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9040", + "filePath": "resourceFile9040"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9041", + "filePath": "resourceFile9041"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9042", + "filePath": "resourceFile9042"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9043", + "filePath": "resourceFile9043"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9044", + "filePath": "resourceFile9044"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9045", + "filePath": "resourceFile9045"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9046", + "filePath": "resourceFile9046"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9047", + "filePath": "resourceFile9047"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9048", + "filePath": "resourceFile9048"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9049", + "filePath": "resourceFile9049"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9050", + "filePath": "resourceFile9050"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9051", + "filePath": "resourceFile9051"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9052", + "filePath": "resourceFile9052"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9053", + "filePath": "resourceFile9053"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9054", + "filePath": "resourceFile9054"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9055", + "filePath": "resourceFile9055"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9056", + "filePath": "resourceFile9056"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9057", + "filePath": "resourceFile9057"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9058", + "filePath": "resourceFile9058"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9059", + "filePath": "resourceFile9059"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9060", + "filePath": "resourceFile9060"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9061", + "filePath": "resourceFile9061"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9062", + "filePath": "resourceFile9062"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9063", + "filePath": "resourceFile9063"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9064", + "filePath": "resourceFile9064"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9065", + "filePath": "resourceFile9065"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9066", + "filePath": "resourceFile9066"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9067", + "filePath": "resourceFile9067"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9068", + "filePath": "resourceFile9068"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9069", + "filePath": "resourceFile9069"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9070", + "filePath": "resourceFile9070"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9071", + "filePath": "resourceFile9071"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9072", + "filePath": "resourceFile9072"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9073", + "filePath": "resourceFile9073"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9074", + "filePath": "resourceFile9074"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9075", + "filePath": "resourceFile9075"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9076", + "filePath": "resourceFile9076"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9077", + "filePath": "resourceFile9077"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9078", + "filePath": "resourceFile9078"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9079", + "filePath": "resourceFile9079"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9080", + "filePath": "resourceFile9080"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9081", + "filePath": "resourceFile9081"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9082", + "filePath": "resourceFile9082"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9083", + "filePath": "resourceFile9083"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9084", + "filePath": "resourceFile9084"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9085", + "filePath": "resourceFile9085"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9086", + "filePath": "resourceFile9086"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9087", + "filePath": "resourceFile9087"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9088", + "filePath": "resourceFile9088"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9089", + "filePath": "resourceFile9089"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9090", + "filePath": "resourceFile9090"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9091", + "filePath": "resourceFile9091"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9092", + "filePath": "resourceFile9092"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9093", + "filePath": "resourceFile9093"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9094", + "filePath": "resourceFile9094"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9095", + "filePath": "resourceFile9095"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9096", + "filePath": "resourceFile9096"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9097", + "filePath": "resourceFile9097"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9098", + "filePath": "resourceFile9098"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9099", + "filePath": "resourceFile9099"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9100", + "filePath": "resourceFile9100"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9101", + "filePath": "resourceFile9101"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9102", + "filePath": "resourceFile9102"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9103", + "filePath": "resourceFile9103"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9104", + "filePath": "resourceFile9104"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9105", + "filePath": "resourceFile9105"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9106", + "filePath": "resourceFile9106"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9107", + "filePath": "resourceFile9107"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9108", + "filePath": "resourceFile9108"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9109", + "filePath": "resourceFile9109"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9110", + "filePath": "resourceFile9110"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9111", + "filePath": "resourceFile9111"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9112", + "filePath": "resourceFile9112"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9113", + "filePath": "resourceFile9113"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9114", + "filePath": "resourceFile9114"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9115", + "filePath": "resourceFile9115"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9116", + "filePath": "resourceFile9116"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9117", + "filePath": "resourceFile9117"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9118", + "filePath": "resourceFile9118"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9119", + "filePath": "resourceFile9119"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9120", + "filePath": "resourceFile9120"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9121", + "filePath": "resourceFile9121"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9122", + "filePath": "resourceFile9122"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9123", + "filePath": "resourceFile9123"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9124", + "filePath": "resourceFile9124"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9125", + "filePath": "resourceFile9125"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9126", + "filePath": "resourceFile9126"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9127", + "filePath": "resourceFile9127"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9128", + "filePath": "resourceFile9128"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9129", + "filePath": "resourceFile9129"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9130", + "filePath": "resourceFile9130"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9131", + "filePath": "resourceFile9131"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9132", + "filePath": "resourceFile9132"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9133", + "filePath": "resourceFile9133"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9134", + "filePath": "resourceFile9134"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9135", + "filePath": "resourceFile9135"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9136", + "filePath": "resourceFile9136"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9137", + "filePath": "resourceFile9137"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9138", + "filePath": "resourceFile9138"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9139", + "filePath": "resourceFile9139"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9140", + "filePath": "resourceFile9140"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9141", + "filePath": "resourceFile9141"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9142", + "filePath": "resourceFile9142"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9143", + "filePath": "resourceFile9143"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9144", + "filePath": "resourceFile9144"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9145", + "filePath": "resourceFile9145"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9146", + "filePath": "resourceFile9146"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9147", + "filePath": "resourceFile9147"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9148", + "filePath": "resourceFile9148"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9149", + "filePath": "resourceFile9149"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9150", + "filePath": "resourceFile9150"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9151", + "filePath": "resourceFile9151"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9152", + "filePath": "resourceFile9152"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9153", + "filePath": "resourceFile9153"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9154", + "filePath": "resourceFile9154"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9155", + "filePath": "resourceFile9155"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9156", + "filePath": "resourceFile9156"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9157", + "filePath": "resourceFile9157"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9158", + "filePath": "resourceFile9158"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9159", + "filePath": "resourceFile9159"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9160", + "filePath": "resourceFile9160"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9161", + "filePath": "resourceFile9161"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9162", + "filePath": "resourceFile9162"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9163", + "filePath": "resourceFile9163"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9164", + "filePath": "resourceFile9164"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9165", + "filePath": "resourceFile9165"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9166", + "filePath": "resourceFile9166"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9167", + "filePath": "resourceFile9167"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9168", + "filePath": "resourceFile9168"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9169", + "filePath": "resourceFile9169"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9170", + "filePath": "resourceFile9170"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9171", + "filePath": "resourceFile9171"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9172", + "filePath": "resourceFile9172"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9173", + "filePath": "resourceFile9173"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9174", + "filePath": "resourceFile9174"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9175", + "filePath": "resourceFile9175"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9176", + "filePath": "resourceFile9176"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9177", + "filePath": "resourceFile9177"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9178", + "filePath": "resourceFile9178"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9179", + "filePath": "resourceFile9179"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9180", + "filePath": "resourceFile9180"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9181", + "filePath": "resourceFile9181"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9182", + "filePath": "resourceFile9182"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9183", + "filePath": "resourceFile9183"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9184", + "filePath": "resourceFile9184"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9185", + "filePath": "resourceFile9185"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9186", + "filePath": "resourceFile9186"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9187", + "filePath": "resourceFile9187"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9188", + "filePath": "resourceFile9188"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9189", + "filePath": "resourceFile9189"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9190", + "filePath": "resourceFile9190"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9191", + "filePath": "resourceFile9191"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9192", + "filePath": "resourceFile9192"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9193", + "filePath": "resourceFile9193"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9194", + "filePath": "resourceFile9194"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9195", + "filePath": "resourceFile9195"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9196", + "filePath": "resourceFile9196"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9197", + "filePath": "resourceFile9197"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9198", + "filePath": "resourceFile9198"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9199", + "filePath": "resourceFile9199"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9200", + "filePath": "resourceFile9200"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9201", + "filePath": "resourceFile9201"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9202", + "filePath": "resourceFile9202"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9203", + "filePath": "resourceFile9203"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9204", + "filePath": "resourceFile9204"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9205", + "filePath": "resourceFile9205"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9206", + "filePath": "resourceFile9206"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9207", + "filePath": "resourceFile9207"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9208", + "filePath": "resourceFile9208"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9209", + "filePath": "resourceFile9209"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9210", + "filePath": "resourceFile9210"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9211", + "filePath": "resourceFile9211"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9212", + "filePath": "resourceFile9212"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9213", + "filePath": "resourceFile9213"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9214", + "filePath": "resourceFile9214"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9215", + "filePath": "resourceFile9215"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9216", + "filePath": "resourceFile9216"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9217", + "filePath": "resourceFile9217"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9218", + "filePath": "resourceFile9218"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9219", + "filePath": "resourceFile9219"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9220", + "filePath": "resourceFile9220"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9221", + "filePath": "resourceFile9221"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9222", + "filePath": "resourceFile9222"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9223", + "filePath": "resourceFile9223"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9224", + "filePath": "resourceFile9224"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9225", + "filePath": "resourceFile9225"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9226", + "filePath": "resourceFile9226"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9227", + "filePath": "resourceFile9227"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9228", + "filePath": "resourceFile9228"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9229", + "filePath": "resourceFile9229"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9230", + "filePath": "resourceFile9230"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9231", + "filePath": "resourceFile9231"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9232", + "filePath": "resourceFile9232"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9233", + "filePath": "resourceFile9233"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9234", + "filePath": "resourceFile9234"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9235", + "filePath": "resourceFile9235"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9236", + "filePath": "resourceFile9236"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9237", + "filePath": "resourceFile9237"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9238", + "filePath": "resourceFile9238"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9239", + "filePath": "resourceFile9239"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9240", + "filePath": "resourceFile9240"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9241", + "filePath": "resourceFile9241"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9242", + "filePath": "resourceFile9242"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9243", + "filePath": "resourceFile9243"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9244", + "filePath": "resourceFile9244"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9245", + "filePath": "resourceFile9245"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9246", + "filePath": "resourceFile9246"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9247", + "filePath": "resourceFile9247"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9248", + "filePath": "resourceFile9248"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9249", + "filePath": "resourceFile9249"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9250", + "filePath": "resourceFile9250"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9251", + "filePath": "resourceFile9251"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9252", + "filePath": "resourceFile9252"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9253", + "filePath": "resourceFile9253"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9254", + "filePath": "resourceFile9254"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9255", + "filePath": "resourceFile9255"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9256", + "filePath": "resourceFile9256"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9257", + "filePath": "resourceFile9257"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9258", + "filePath": "resourceFile9258"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9259", + "filePath": "resourceFile9259"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9260", + "filePath": "resourceFile9260"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9261", + "filePath": "resourceFile9261"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9262", + "filePath": "resourceFile9262"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9263", + "filePath": "resourceFile9263"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9264", + "filePath": "resourceFile9264"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9265", + "filePath": "resourceFile9265"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9266", + "filePath": "resourceFile9266"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9267", + "filePath": "resourceFile9267"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9268", + "filePath": "resourceFile9268"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9269", + "filePath": "resourceFile9269"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9270", + "filePath": "resourceFile9270"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9271", + "filePath": "resourceFile9271"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9272", + "filePath": "resourceFile9272"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9273", + "filePath": "resourceFile9273"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9274", + "filePath": "resourceFile9274"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9275", + "filePath": "resourceFile9275"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9276", + "filePath": "resourceFile9276"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9277", + "filePath": "resourceFile9277"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9278", + "filePath": "resourceFile9278"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9279", + "filePath": "resourceFile9279"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9280", + "filePath": "resourceFile9280"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9281", + "filePath": "resourceFile9281"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9282", + "filePath": "resourceFile9282"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9283", + "filePath": "resourceFile9283"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9284", + "filePath": "resourceFile9284"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9285", + "filePath": "resourceFile9285"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9286", + "filePath": "resourceFile9286"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9287", + "filePath": "resourceFile9287"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9288", + "filePath": "resourceFile9288"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9289", + "filePath": "resourceFile9289"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9290", + "filePath": "resourceFile9290"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9291", + "filePath": "resourceFile9291"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9292", + "filePath": "resourceFile9292"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9293", + "filePath": "resourceFile9293"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9294", + "filePath": "resourceFile9294"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9295", + "filePath": "resourceFile9295"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9296", + "filePath": "resourceFile9296"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9297", + "filePath": "resourceFile9297"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9298", + "filePath": "resourceFile9298"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9299", + "filePath": "resourceFile9299"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9300", + "filePath": "resourceFile9300"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9301", + "filePath": "resourceFile9301"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9302", + "filePath": "resourceFile9302"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9303", + "filePath": "resourceFile9303"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9304", + "filePath": "resourceFile9304"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9305", + "filePath": "resourceFile9305"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9306", + "filePath": "resourceFile9306"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9307", + "filePath": "resourceFile9307"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9308", + "filePath": "resourceFile9308"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9309", + "filePath": "resourceFile9309"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9310", + "filePath": "resourceFile9310"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9311", + "filePath": "resourceFile9311"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9312", + "filePath": "resourceFile9312"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9313", + "filePath": "resourceFile9313"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9314", + "filePath": "resourceFile9314"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9315", + "filePath": "resourceFile9315"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9316", + "filePath": "resourceFile9316"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9317", + "filePath": "resourceFile9317"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9318", + "filePath": "resourceFile9318"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9319", + "filePath": "resourceFile9319"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9320", + "filePath": "resourceFile9320"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9321", + "filePath": "resourceFile9321"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9322", + "filePath": "resourceFile9322"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9323", + "filePath": "resourceFile9323"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9324", + "filePath": "resourceFile9324"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9325", + "filePath": "resourceFile9325"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9326", + "filePath": "resourceFile9326"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9327", + "filePath": "resourceFile9327"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9328", + "filePath": "resourceFile9328"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9329", + "filePath": "resourceFile9329"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9330", + "filePath": "resourceFile9330"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9331", + "filePath": "resourceFile9331"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9332", + "filePath": "resourceFile9332"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9333", + "filePath": "resourceFile9333"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9334", + "filePath": "resourceFile9334"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9335", + "filePath": "resourceFile9335"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9336", + "filePath": "resourceFile9336"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9337", + "filePath": "resourceFile9337"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9338", + "filePath": "resourceFile9338"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9339", + "filePath": "resourceFile9339"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9340", + "filePath": "resourceFile9340"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9341", + "filePath": "resourceFile9341"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9342", + "filePath": "resourceFile9342"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9343", + "filePath": "resourceFile9343"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9344", + "filePath": "resourceFile9344"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9345", + "filePath": "resourceFile9345"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9346", + "filePath": "resourceFile9346"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9347", + "filePath": "resourceFile9347"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9348", + "filePath": "resourceFile9348"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9349", + "filePath": "resourceFile9349"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9350", + "filePath": "resourceFile9350"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9351", + "filePath": "resourceFile9351"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9352", + "filePath": "resourceFile9352"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9353", + "filePath": "resourceFile9353"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9354", + "filePath": "resourceFile9354"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9355", + "filePath": "resourceFile9355"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9356", + "filePath": "resourceFile9356"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9357", + "filePath": "resourceFile9357"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9358", + "filePath": "resourceFile9358"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9359", + "filePath": "resourceFile9359"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9360", + "filePath": "resourceFile9360"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9361", + "filePath": "resourceFile9361"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9362", + "filePath": "resourceFile9362"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9363", + "filePath": "resourceFile9363"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9364", + "filePath": "resourceFile9364"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9365", + "filePath": "resourceFile9365"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9366", + "filePath": "resourceFile9366"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9367", + "filePath": "resourceFile9367"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9368", + "filePath": "resourceFile9368"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9369", + "filePath": "resourceFile9369"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9370", + "filePath": "resourceFile9370"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9371", + "filePath": "resourceFile9371"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9372", + "filePath": "resourceFile9372"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9373", + "filePath": "resourceFile9373"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9374", + "filePath": "resourceFile9374"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9375", + "filePath": "resourceFile9375"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9376", + "filePath": "resourceFile9376"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9377", + "filePath": "resourceFile9377"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9378", + "filePath": "resourceFile9378"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9379", + "filePath": "resourceFile9379"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9380", + "filePath": "resourceFile9380"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9381", + "filePath": "resourceFile9381"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9382", + "filePath": "resourceFile9382"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9383", + "filePath": "resourceFile9383"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9384", + "filePath": "resourceFile9384"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9385", + "filePath": "resourceFile9385"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9386", + "filePath": "resourceFile9386"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9387", + "filePath": "resourceFile9387"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9388", + "filePath": "resourceFile9388"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9389", + "filePath": "resourceFile9389"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9390", + "filePath": "resourceFile9390"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9391", + "filePath": "resourceFile9391"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9392", + "filePath": "resourceFile9392"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9393", + "filePath": "resourceFile9393"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9394", + "filePath": "resourceFile9394"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9395", + "filePath": "resourceFile9395"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9396", + "filePath": "resourceFile9396"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9397", + "filePath": "resourceFile9397"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9398", + "filePath": "resourceFile9398"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9399", + "filePath": "resourceFile9399"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9400", + "filePath": "resourceFile9400"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9401", + "filePath": "resourceFile9401"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9402", + "filePath": "resourceFile9402"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9403", + "filePath": "resourceFile9403"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9404", + "filePath": "resourceFile9404"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9405", + "filePath": "resourceFile9405"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9406", + "filePath": "resourceFile9406"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9407", + "filePath": "resourceFile9407"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9408", + "filePath": "resourceFile9408"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9409", + "filePath": "resourceFile9409"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9410", + "filePath": "resourceFile9410"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9411", + "filePath": "resourceFile9411"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9412", + "filePath": "resourceFile9412"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9413", + "filePath": "resourceFile9413"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9414", + "filePath": "resourceFile9414"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9415", + "filePath": "resourceFile9415"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9416", + "filePath": "resourceFile9416"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9417", + "filePath": "resourceFile9417"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9418", + "filePath": "resourceFile9418"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9419", + "filePath": "resourceFile9419"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9420", + "filePath": "resourceFile9420"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9421", + "filePath": "resourceFile9421"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9422", + "filePath": "resourceFile9422"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9423", + "filePath": "resourceFile9423"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9424", + "filePath": "resourceFile9424"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9425", + "filePath": "resourceFile9425"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9426", + "filePath": "resourceFile9426"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9427", + "filePath": "resourceFile9427"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9428", + "filePath": "resourceFile9428"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9429", + "filePath": "resourceFile9429"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9430", + "filePath": "resourceFile9430"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9431", + "filePath": "resourceFile9431"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9432", + "filePath": "resourceFile9432"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9433", + "filePath": "resourceFile9433"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9434", + "filePath": "resourceFile9434"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9435", + "filePath": "resourceFile9435"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9436", + "filePath": "resourceFile9436"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9437", + "filePath": "resourceFile9437"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9438", + "filePath": "resourceFile9438"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9439", + "filePath": "resourceFile9439"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9440", + "filePath": "resourceFile9440"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9441", + "filePath": "resourceFile9441"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9442", + "filePath": "resourceFile9442"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9443", + "filePath": "resourceFile9443"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9444", + "filePath": "resourceFile9444"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9445", + "filePath": "resourceFile9445"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9446", + "filePath": "resourceFile9446"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9447", + "filePath": "resourceFile9447"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9448", + "filePath": "resourceFile9448"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9449", + "filePath": "resourceFile9449"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9450", + "filePath": "resourceFile9450"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9451", + "filePath": "resourceFile9451"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9452", + "filePath": "resourceFile9452"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9453", + "filePath": "resourceFile9453"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9454", + "filePath": "resourceFile9454"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9455", + "filePath": "resourceFile9455"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9456", + "filePath": "resourceFile9456"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9457", + "filePath": "resourceFile9457"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9458", + "filePath": "resourceFile9458"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9459", + "filePath": "resourceFile9459"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9460", + "filePath": "resourceFile9460"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9461", + "filePath": "resourceFile9461"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9462", + "filePath": "resourceFile9462"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9463", + "filePath": "resourceFile9463"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9464", + "filePath": "resourceFile9464"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9465", + "filePath": "resourceFile9465"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9466", + "filePath": "resourceFile9466"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9467", + "filePath": "resourceFile9467"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9468", + "filePath": "resourceFile9468"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9469", + "filePath": "resourceFile9469"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9470", + "filePath": "resourceFile9470"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9471", + "filePath": "resourceFile9471"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9472", + "filePath": "resourceFile9472"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9473", + "filePath": "resourceFile9473"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9474", + "filePath": "resourceFile9474"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9475", + "filePath": "resourceFile9475"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9476", + "filePath": "resourceFile9476"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9477", + "filePath": "resourceFile9477"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9478", + "filePath": "resourceFile9478"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9479", + "filePath": "resourceFile9479"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9480", + "filePath": "resourceFile9480"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9481", + "filePath": "resourceFile9481"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9482", + "filePath": "resourceFile9482"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9483", + "filePath": "resourceFile9483"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9484", + "filePath": "resourceFile9484"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9485", + "filePath": "resourceFile9485"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9486", + "filePath": "resourceFile9486"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9487", + "filePath": "resourceFile9487"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9488", + "filePath": "resourceFile9488"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9489", + "filePath": "resourceFile9489"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9490", + "filePath": "resourceFile9490"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9491", + "filePath": "resourceFile9491"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9492", + "filePath": "resourceFile9492"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9493", + "filePath": "resourceFile9493"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9494", + "filePath": "resourceFile9494"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9495", + "filePath": "resourceFile9495"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9496", + "filePath": "resourceFile9496"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9497", + "filePath": "resourceFile9497"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9498", + "filePath": "resourceFile9498"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9499", + "filePath": "resourceFile9499"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9500", + "filePath": "resourceFile9500"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9501", + "filePath": "resourceFile9501"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9502", + "filePath": "resourceFile9502"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9503", + "filePath": "resourceFile9503"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9504", + "filePath": "resourceFile9504"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9505", + "filePath": "resourceFile9505"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9506", + "filePath": "resourceFile9506"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9507", + "filePath": "resourceFile9507"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9508", + "filePath": "resourceFile9508"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9509", + "filePath": "resourceFile9509"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9510", + "filePath": "resourceFile9510"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9511", + "filePath": "resourceFile9511"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9512", + "filePath": "resourceFile9512"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9513", + "filePath": "resourceFile9513"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9514", + "filePath": "resourceFile9514"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9515", + "filePath": "resourceFile9515"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9516", + "filePath": "resourceFile9516"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9517", + "filePath": "resourceFile9517"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9518", + "filePath": "resourceFile9518"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9519", + "filePath": "resourceFile9519"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9520", + "filePath": "resourceFile9520"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9521", + "filePath": "resourceFile9521"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9522", + "filePath": "resourceFile9522"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9523", + "filePath": "resourceFile9523"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9524", + "filePath": "resourceFile9524"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9525", + "filePath": "resourceFile9525"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9526", + "filePath": "resourceFile9526"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9527", + "filePath": "resourceFile9527"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9528", + "filePath": "resourceFile9528"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9529", + "filePath": "resourceFile9529"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9530", + "filePath": "resourceFile9530"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9531", + "filePath": "resourceFile9531"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9532", + "filePath": "resourceFile9532"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9533", + "filePath": "resourceFile9533"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9534", + "filePath": "resourceFile9534"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9535", + "filePath": "resourceFile9535"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9536", + "filePath": "resourceFile9536"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9537", + "filePath": "resourceFile9537"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9538", + "filePath": "resourceFile9538"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9539", + "filePath": "resourceFile9539"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9540", + "filePath": "resourceFile9540"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9541", + "filePath": "resourceFile9541"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9542", + "filePath": "resourceFile9542"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9543", + "filePath": "resourceFile9543"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9544", + "filePath": "resourceFile9544"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9545", + "filePath": "resourceFile9545"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9546", + "filePath": "resourceFile9546"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9547", + "filePath": "resourceFile9547"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9548", + "filePath": "resourceFile9548"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9549", + "filePath": "resourceFile9549"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9550", + "filePath": "resourceFile9550"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9551", + "filePath": "resourceFile9551"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9552", + "filePath": "resourceFile9552"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9553", + "filePath": "resourceFile9553"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9554", + "filePath": "resourceFile9554"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9555", + "filePath": "resourceFile9555"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9556", + "filePath": "resourceFile9556"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9557", + "filePath": "resourceFile9557"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9558", + "filePath": "resourceFile9558"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9559", + "filePath": "resourceFile9559"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9560", + "filePath": "resourceFile9560"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9561", + "filePath": "resourceFile9561"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9562", + "filePath": "resourceFile9562"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9563", + "filePath": "resourceFile9563"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9564", + "filePath": "resourceFile9564"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9565", + "filePath": "resourceFile9565"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9566", + "filePath": "resourceFile9566"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9567", + "filePath": "resourceFile9567"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9568", + "filePath": "resourceFile9568"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9569", + "filePath": "resourceFile9569"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9570", + "filePath": "resourceFile9570"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9571", + "filePath": "resourceFile9571"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9572", + "filePath": "resourceFile9572"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9573", + "filePath": "resourceFile9573"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9574", + "filePath": "resourceFile9574"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9575", + "filePath": "resourceFile9575"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9576", + "filePath": "resourceFile9576"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9577", + "filePath": "resourceFile9577"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9578", + "filePath": "resourceFile9578"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9579", + "filePath": "resourceFile9579"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9580", + "filePath": "resourceFile9580"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9581", + "filePath": "resourceFile9581"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9582", + "filePath": "resourceFile9582"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9583", + "filePath": "resourceFile9583"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9584", + "filePath": "resourceFile9584"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9585", + "filePath": "resourceFile9585"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9586", + "filePath": "resourceFile9586"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9587", + "filePath": "resourceFile9587"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9588", + "filePath": "resourceFile9588"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9589", + "filePath": "resourceFile9589"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9590", + "filePath": "resourceFile9590"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9591", + "filePath": "resourceFile9591"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9592", + "filePath": "resourceFile9592"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9593", + "filePath": "resourceFile9593"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9594", + "filePath": "resourceFile9594"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9595", + "filePath": "resourceFile9595"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9596", + "filePath": "resourceFile9596"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9597", + "filePath": "resourceFile9597"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9598", + "filePath": "resourceFile9598"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9599", + "filePath": "resourceFile9599"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9600", + "filePath": "resourceFile9600"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9601", + "filePath": "resourceFile9601"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9602", + "filePath": "resourceFile9602"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9603", + "filePath": "resourceFile9603"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9604", + "filePath": "resourceFile9604"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9605", + "filePath": "resourceFile9605"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9606", + "filePath": "resourceFile9606"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9607", + "filePath": "resourceFile9607"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9608", + "filePath": "resourceFile9608"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9609", + "filePath": "resourceFile9609"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9610", + "filePath": "resourceFile9610"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9611", + "filePath": "resourceFile9611"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9612", + "filePath": "resourceFile9612"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9613", + "filePath": "resourceFile9613"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9614", + "filePath": "resourceFile9614"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9615", + "filePath": "resourceFile9615"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9616", + "filePath": "resourceFile9616"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9617", + "filePath": "resourceFile9617"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9618", + "filePath": "resourceFile9618"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9619", + "filePath": "resourceFile9619"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9620", + "filePath": "resourceFile9620"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9621", + "filePath": "resourceFile9621"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9622", + "filePath": "resourceFile9622"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9623", + "filePath": "resourceFile9623"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9624", + "filePath": "resourceFile9624"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9625", + "filePath": "resourceFile9625"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9626", + "filePath": "resourceFile9626"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9627", + "filePath": "resourceFile9627"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9628", + "filePath": "resourceFile9628"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9629", + "filePath": "resourceFile9629"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9630", + "filePath": "resourceFile9630"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9631", + "filePath": "resourceFile9631"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9632", + "filePath": "resourceFile9632"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9633", + "filePath": "resourceFile9633"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9634", + "filePath": "resourceFile9634"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9635", + "filePath": "resourceFile9635"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9636", + "filePath": "resourceFile9636"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9637", + "filePath": "resourceFile9637"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9638", + "filePath": "resourceFile9638"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9639", + "filePath": "resourceFile9639"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9640", + "filePath": "resourceFile9640"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9641", + "filePath": "resourceFile9641"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9642", + "filePath": "resourceFile9642"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9643", + "filePath": "resourceFile9643"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9644", + "filePath": "resourceFile9644"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9645", + "filePath": "resourceFile9645"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9646", + "filePath": "resourceFile9646"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9647", + "filePath": "resourceFile9647"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9648", + "filePath": "resourceFile9648"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9649", + "filePath": "resourceFile9649"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9650", + "filePath": "resourceFile9650"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9651", + "filePath": "resourceFile9651"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9652", + "filePath": "resourceFile9652"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9653", + "filePath": "resourceFile9653"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9654", + "filePath": "resourceFile9654"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9655", + "filePath": "resourceFile9655"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9656", + "filePath": "resourceFile9656"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9657", + "filePath": "resourceFile9657"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9658", + "filePath": "resourceFile9658"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9659", + "filePath": "resourceFile9659"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9660", + "filePath": "resourceFile9660"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9661", + "filePath": "resourceFile9661"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9662", + "filePath": "resourceFile9662"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9663", + "filePath": "resourceFile9663"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9664", + "filePath": "resourceFile9664"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9665", + "filePath": "resourceFile9665"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9666", + "filePath": "resourceFile9666"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9667", + "filePath": "resourceFile9667"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9668", + "filePath": "resourceFile9668"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9669", + "filePath": "resourceFile9669"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9670", + "filePath": "resourceFile9670"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9671", + "filePath": "resourceFile9671"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9672", + "filePath": "resourceFile9672"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9673", + "filePath": "resourceFile9673"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9674", + "filePath": "resourceFile9674"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9675", + "filePath": "resourceFile9675"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9676", + "filePath": "resourceFile9676"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9677", + "filePath": "resourceFile9677"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9678", + "filePath": "resourceFile9678"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9679", + "filePath": "resourceFile9679"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9680", + "filePath": "resourceFile9680"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9681", + "filePath": "resourceFile9681"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9682", + "filePath": "resourceFile9682"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9683", + "filePath": "resourceFile9683"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9684", + "filePath": "resourceFile9684"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9685", + "filePath": "resourceFile9685"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9686", + "filePath": "resourceFile9686"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9687", + "filePath": "resourceFile9687"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9688", + "filePath": "resourceFile9688"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9689", + "filePath": "resourceFile9689"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9690", + "filePath": "resourceFile9690"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9691", + "filePath": "resourceFile9691"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9692", + "filePath": "resourceFile9692"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9693", + "filePath": "resourceFile9693"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9694", + "filePath": "resourceFile9694"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9695", + "filePath": "resourceFile9695"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9696", + "filePath": "resourceFile9696"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9697", + "filePath": "resourceFile9697"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9698", + "filePath": "resourceFile9698"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9699", + "filePath": "resourceFile9699"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9700", + "filePath": "resourceFile9700"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9701", + "filePath": "resourceFile9701"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9702", + "filePath": "resourceFile9702"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9703", + "filePath": "resourceFile9703"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9704", + "filePath": "resourceFile9704"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9705", + "filePath": "resourceFile9705"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9706", + "filePath": "resourceFile9706"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9707", + "filePath": "resourceFile9707"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9708", + "filePath": "resourceFile9708"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9709", + "filePath": "resourceFile9709"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9710", + "filePath": "resourceFile9710"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9711", + "filePath": "resourceFile9711"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9712", + "filePath": "resourceFile9712"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9713", + "filePath": "resourceFile9713"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9714", + "filePath": "resourceFile9714"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9715", + "filePath": "resourceFile9715"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9716", + "filePath": "resourceFile9716"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9717", + "filePath": "resourceFile9717"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9718", + "filePath": "resourceFile9718"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9719", + "filePath": "resourceFile9719"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9720", + "filePath": "resourceFile9720"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9721", + "filePath": "resourceFile9721"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9722", + "filePath": "resourceFile9722"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9723", + "filePath": "resourceFile9723"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9724", + "filePath": "resourceFile9724"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9725", + "filePath": "resourceFile9725"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9726", + "filePath": "resourceFile9726"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9727", + "filePath": "resourceFile9727"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9728", + "filePath": "resourceFile9728"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9729", + "filePath": "resourceFile9729"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9730", + "filePath": "resourceFile9730"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9731", + "filePath": "resourceFile9731"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9732", + "filePath": "resourceFile9732"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9733", + "filePath": "resourceFile9733"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9734", + "filePath": "resourceFile9734"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9735", + "filePath": "resourceFile9735"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9736", + "filePath": "resourceFile9736"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9737", + "filePath": "resourceFile9737"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9738", + "filePath": "resourceFile9738"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9739", + "filePath": "resourceFile9739"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9740", + "filePath": "resourceFile9740"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9741", + "filePath": "resourceFile9741"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9742", + "filePath": "resourceFile9742"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9743", + "filePath": "resourceFile9743"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9744", + "filePath": "resourceFile9744"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9745", + "filePath": "resourceFile9745"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9746", + "filePath": "resourceFile9746"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9747", + "filePath": "resourceFile9747"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9748", + "filePath": "resourceFile9748"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9749", + "filePath": "resourceFile9749"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9750", + "filePath": "resourceFile9750"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9751", + "filePath": "resourceFile9751"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9752", + "filePath": "resourceFile9752"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9753", + "filePath": "resourceFile9753"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9754", + "filePath": "resourceFile9754"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9755", + "filePath": "resourceFile9755"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9756", + "filePath": "resourceFile9756"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9757", + "filePath": "resourceFile9757"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9758", + "filePath": "resourceFile9758"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9759", + "filePath": "resourceFile9759"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9760", + "filePath": "resourceFile9760"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9761", + "filePath": "resourceFile9761"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9762", + "filePath": "resourceFile9762"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9763", + "filePath": "resourceFile9763"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9764", + "filePath": "resourceFile9764"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9765", + "filePath": "resourceFile9765"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9766", + "filePath": "resourceFile9766"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9767", + "filePath": "resourceFile9767"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9768", + "filePath": "resourceFile9768"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9769", + "filePath": "resourceFile9769"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9770", + "filePath": "resourceFile9770"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9771", + "filePath": "resourceFile9771"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9772", + "filePath": "resourceFile9772"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9773", + "filePath": "resourceFile9773"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9774", + "filePath": "resourceFile9774"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9775", + "filePath": "resourceFile9775"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9776", + "filePath": "resourceFile9776"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9777", + "filePath": "resourceFile9777"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9778", + "filePath": "resourceFile9778"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9779", + "filePath": "resourceFile9779"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9780", + "filePath": "resourceFile9780"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9781", + "filePath": "resourceFile9781"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9782", + "filePath": "resourceFile9782"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9783", + "filePath": "resourceFile9783"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9784", + "filePath": "resourceFile9784"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9785", + "filePath": "resourceFile9785"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9786", + "filePath": "resourceFile9786"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9787", + "filePath": "resourceFile9787"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9788", + "filePath": "resourceFile9788"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9789", + "filePath": "resourceFile9789"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9790", + "filePath": "resourceFile9790"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9791", + "filePath": "resourceFile9791"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9792", + "filePath": "resourceFile9792"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9793", + "filePath": "resourceFile9793"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9794", + "filePath": "resourceFile9794"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9795", + "filePath": "resourceFile9795"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9796", + "filePath": "resourceFile9796"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9797", + "filePath": "resourceFile9797"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9798", + "filePath": "resourceFile9798"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9799", + "filePath": "resourceFile9799"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9800", + "filePath": "resourceFile9800"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9801", + "filePath": "resourceFile9801"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9802", + "filePath": "resourceFile9802"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9803", + "filePath": "resourceFile9803"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9804", + "filePath": "resourceFile9804"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9805", + "filePath": "resourceFile9805"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9806", + "filePath": "resourceFile9806"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9807", + "filePath": "resourceFile9807"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9808", + "filePath": "resourceFile9808"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9809", + "filePath": "resourceFile9809"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9810", + "filePath": "resourceFile9810"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9811", + "filePath": "resourceFile9811"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9812", + "filePath": "resourceFile9812"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9813", + "filePath": "resourceFile9813"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9814", + "filePath": "resourceFile9814"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9815", + "filePath": "resourceFile9815"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9816", + "filePath": "resourceFile9816"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9817", + "filePath": "resourceFile9817"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9818", + "filePath": "resourceFile9818"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9819", + "filePath": "resourceFile9819"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9820", + "filePath": "resourceFile9820"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9821", + "filePath": "resourceFile9821"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9822", + "filePath": "resourceFile9822"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9823", + "filePath": "resourceFile9823"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9824", + "filePath": "resourceFile9824"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9825", + "filePath": "resourceFile9825"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9826", + "filePath": "resourceFile9826"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9827", + "filePath": "resourceFile9827"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9828", + "filePath": "resourceFile9828"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9829", + "filePath": "resourceFile9829"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9830", + "filePath": "resourceFile9830"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9831", + "filePath": "resourceFile9831"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9832", + "filePath": "resourceFile9832"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9833", + "filePath": "resourceFile9833"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9834", + "filePath": "resourceFile9834"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9835", + "filePath": "resourceFile9835"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9836", + "filePath": "resourceFile9836"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9837", + "filePath": "resourceFile9837"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9838", + "filePath": "resourceFile9838"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9839", + "filePath": "resourceFile9839"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9840", + "filePath": "resourceFile9840"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9841", + "filePath": "resourceFile9841"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9842", + "filePath": "resourceFile9842"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9843", + "filePath": "resourceFile9843"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9844", + "filePath": "resourceFile9844"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9845", + "filePath": "resourceFile9845"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9846", + "filePath": "resourceFile9846"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9847", + "filePath": "resourceFile9847"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9848", + "filePath": "resourceFile9848"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9849", + "filePath": "resourceFile9849"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9850", + "filePath": "resourceFile9850"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9851", + "filePath": "resourceFile9851"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9852", + "filePath": "resourceFile9852"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9853", + "filePath": "resourceFile9853"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9854", + "filePath": "resourceFile9854"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9855", + "filePath": "resourceFile9855"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9856", + "filePath": "resourceFile9856"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9857", + "filePath": "resourceFile9857"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9858", + "filePath": "resourceFile9858"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9859", + "filePath": "resourceFile9859"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9860", + "filePath": "resourceFile9860"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9861", + "filePath": "resourceFile9861"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9862", + "filePath": "resourceFile9862"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9863", + "filePath": "resourceFile9863"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9864", + "filePath": "resourceFile9864"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9865", + "filePath": "resourceFile9865"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9866", + "filePath": "resourceFile9866"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9867", + "filePath": "resourceFile9867"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9868", + "filePath": "resourceFile9868"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9869", + "filePath": "resourceFile9869"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9870", + "filePath": "resourceFile9870"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9871", + "filePath": "resourceFile9871"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9872", + "filePath": "resourceFile9872"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9873", + "filePath": "resourceFile9873"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9874", + "filePath": "resourceFile9874"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9875", + "filePath": "resourceFile9875"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9876", + "filePath": "resourceFile9876"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9877", + "filePath": "resourceFile9877"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9878", + "filePath": "resourceFile9878"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9879", + "filePath": "resourceFile9879"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9880", + "filePath": "resourceFile9880"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9881", + "filePath": "resourceFile9881"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9882", + "filePath": "resourceFile9882"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9883", + "filePath": "resourceFile9883"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9884", + "filePath": "resourceFile9884"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9885", + "filePath": "resourceFile9885"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9886", + "filePath": "resourceFile9886"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9887", + "filePath": "resourceFile9887"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9888", + "filePath": "resourceFile9888"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9889", + "filePath": "resourceFile9889"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9890", + "filePath": "resourceFile9890"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9891", + "filePath": "resourceFile9891"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9892", + "filePath": "resourceFile9892"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9893", + "filePath": "resourceFile9893"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9894", + "filePath": "resourceFile9894"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9895", + "filePath": "resourceFile9895"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9896", + "filePath": "resourceFile9896"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9897", + "filePath": "resourceFile9897"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9898", + "filePath": "resourceFile9898"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9899", + "filePath": "resourceFile9899"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9900", + "filePath": "resourceFile9900"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9901", + "filePath": "resourceFile9901"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9902", + "filePath": "resourceFile9902"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9903", + "filePath": "resourceFile9903"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9904", + "filePath": "resourceFile9904"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9905", + "filePath": "resourceFile9905"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9906", + "filePath": "resourceFile9906"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9907", + "filePath": "resourceFile9907"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9908", + "filePath": "resourceFile9908"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9909", + "filePath": "resourceFile9909"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9910", + "filePath": "resourceFile9910"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9911", + "filePath": "resourceFile9911"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9912", + "filePath": "resourceFile9912"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9913", + "filePath": "resourceFile9913"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9914", + "filePath": "resourceFile9914"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9915", + "filePath": "resourceFile9915"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9916", + "filePath": "resourceFile9916"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9917", + "filePath": "resourceFile9917"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9918", + "filePath": "resourceFile9918"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9919", + "filePath": "resourceFile9919"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9920", + "filePath": "resourceFile9920"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9921", + "filePath": "resourceFile9921"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9922", + "filePath": "resourceFile9922"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9923", + "filePath": "resourceFile9923"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9924", + "filePath": "resourceFile9924"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9925", + "filePath": "resourceFile9925"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9926", + "filePath": "resourceFile9926"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9927", + "filePath": "resourceFile9927"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9928", + "filePath": "resourceFile9928"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9929", + "filePath": "resourceFile9929"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9930", + "filePath": "resourceFile9930"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9931", + "filePath": "resourceFile9931"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9932", + "filePath": "resourceFile9932"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9933", + "filePath": "resourceFile9933"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9934", + "filePath": "resourceFile9934"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9935", + "filePath": "resourceFile9935"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9936", + "filePath": "resourceFile9936"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9937", + "filePath": "resourceFile9937"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9938", + "filePath": "resourceFile9938"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9939", + "filePath": "resourceFile9939"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9940", + "filePath": "resourceFile9940"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9941", + "filePath": "resourceFile9941"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9942", + "filePath": "resourceFile9942"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9943", + "filePath": "resourceFile9943"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9944", + "filePath": "resourceFile9944"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9945", + "filePath": "resourceFile9945"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9946", + "filePath": "resourceFile9946"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9947", + "filePath": "resourceFile9947"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9948", + "filePath": "resourceFile9948"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9949", + "filePath": "resourceFile9949"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9950", + "filePath": "resourceFile9950"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9951", + "filePath": "resourceFile9951"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9952", + "filePath": "resourceFile9952"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9953", + "filePath": "resourceFile9953"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9954", + "filePath": "resourceFile9954"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9955", + "filePath": "resourceFile9955"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9956", + "filePath": "resourceFile9956"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9957", + "filePath": "resourceFile9957"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9958", + "filePath": "resourceFile9958"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9959", + "filePath": "resourceFile9959"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9960", + "filePath": "resourceFile9960"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9961", + "filePath": "resourceFile9961"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9962", + "filePath": "resourceFile9962"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9963", + "filePath": "resourceFile9963"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9964", + "filePath": "resourceFile9964"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9965", + "filePath": "resourceFile9965"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9966", + "filePath": "resourceFile9966"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9967", + "filePath": "resourceFile9967"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9968", + "filePath": "resourceFile9968"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9969", + "filePath": "resourceFile9969"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9970", + "filePath": "resourceFile9970"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9971", + "filePath": "resourceFile9971"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9972", + "filePath": "resourceFile9972"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9973", + "filePath": "resourceFile9973"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9974", + "filePath": "resourceFile9974"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9975", + "filePath": "resourceFile9975"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9976", + "filePath": "resourceFile9976"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9977", + "filePath": "resourceFile9977"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9978", + "filePath": "resourceFile9978"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9979", + "filePath": "resourceFile9979"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9980", + "filePath": "resourceFile9980"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9981", + "filePath": "resourceFile9981"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9982", + "filePath": "resourceFile9982"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9983", + "filePath": "resourceFile9983"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9984", + "filePath": "resourceFile9984"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9985", + "filePath": "resourceFile9985"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9986", + "filePath": "resourceFile9986"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9987", + "filePath": "resourceFile9987"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9988", + "filePath": "resourceFile9988"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9989", + "filePath": "resourceFile9989"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9990", + "filePath": "resourceFile9990"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9991", + "filePath": "resourceFile9991"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9992", + "filePath": "resourceFile9992"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9993", + "filePath": "resourceFile9993"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9994", + "filePath": "resourceFile9994"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9995", + "filePath": "resourceFile9995"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9996", + "filePath": "resourceFile9996"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9997", + "filePath": "resourceFile9997"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9998", + "filePath": "resourceFile9998"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9999", + "filePath": "resourceFile9999"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['1207854'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:29 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#Microsoft.Azure.Batch.Protocol.Entities.Container.errors/@Element\",\"code\":\"RequestBodyTooLarge\",\"message\":{\r\n + \ \"lang\":\"en-US\",\"value\":\"The request body is too large and exceeds + the maximum permissible limit.\\nRequestId:91095a2f-6205-4a48-966a-bba33540bafa\\nTime:2018-09-13T20:24:30.3153553Z\"\r\n + \ },\"values\":[\r\n {\r\n \"key\":\"MaxLimit\",\"value\":\"1048576\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-length: ['451'] + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:30 GMT'] + request-id: [91095a2f-6205-4a48-966a-bba33540bafa] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + x-content-type-options: [nosniff] + status: {code: 413, message: The request body is too large and exceeds the maximum + permissible limit.} +- request: + body: '{"value": [{"id": "mytask732", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask731", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask730", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask729", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask728", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask727", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask726", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask725", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask724", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask723", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask722", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask721", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask720", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask719", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask718", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask717", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask716", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask715", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask714", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask713", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask712", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask711", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask710", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask709", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask708", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask707", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask706", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask705", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask704", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask703", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask702", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask701", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask700", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask699", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask698", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask697", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask696", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask695", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask694", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask693", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask692", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask691", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask690", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask689", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask688", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask687", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask686", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask685", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask684", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask683", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask682", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask681", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask680", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask679", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask678", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask677", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask676", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask675", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask674", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask673", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask672", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask671", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask670", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask669", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask668", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask667", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask666", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask665", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask664", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask663", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask662", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask661", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask660", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask659", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask658", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask657", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask656", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask655", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask654", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask653", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask652", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask651", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask650", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask649", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask648", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask647", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask646", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask645", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask644", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask643", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask642", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask641", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask640", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask639", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask638", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask637", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask636", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask635", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask634", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask633", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['1174611'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:31 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#Microsoft.Azure.Batch.Protocol.Entities.Container.errors/@Element\",\"code\":\"RequestBodyTooLarge\",\"message\":{\r\n + \ \"lang\":\"en-US\",\"value\":\"The request body is too large and exceeds + the maximum permissible limit.\\nRequestId:cff75933-fa80-4bdf-a3f6-2533efcee021\\nTime:2018-09-13T20:24:32.1086560Z\"\r\n + \ },\"values\":[\r\n {\r\n \"key\":\"MaxLimit\",\"value\":\"1048576\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-length: ['451'] + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:32 GMT'] + request-id: [cff75933-fa80-4bdf-a3f6-2533efcee021] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + x-content-type-options: [nosniff] + status: {code: 413, message: The request body is too large and exceeds the maximum + permissible limit.} +- request: + body: '{"value": [{"id": "mytask732", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask731", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask730", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask729", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask728", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask727", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask726", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask725", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask724", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask723", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask722", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask721", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask720", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask719", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask718", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask717", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask716", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask715", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask714", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask713", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask712", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask711", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask710", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask709", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask708", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask707", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask706", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask705", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask704", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask703", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask702", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask701", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask700", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask699", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask698", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask697", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask696", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask695", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask694", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask693", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask692", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask691", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask690", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask689", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask688", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask687", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask686", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask685", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask684", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask683", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:32 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask732\",\"eTag\":\"0x8D619B6EB3A3838\",\"lastModified\":\"2018-09-13T20:24:34.0707384Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask732\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask731\",\"eTag\":\"0x8D619B6EB3AD2CE\",\"lastModified\":\"2018-09-13T20:24:34.0746958Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask731\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask730\",\"eTag\":\"0x8D619B6EB3CF788\",\"lastModified\":\"2018-09-13T20:24:34.0887432Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask730\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask729\",\"eTag\":\"0x8D619B6EB3D91FA\",\"lastModified\":\"2018-09-13T20:24:34.092697Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask729\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask728\",\"eTag\":\"0x8D619B6EB3ECA76\",\"lastModified\":\"2018-09-13T20:24:34.1006966Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask728\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask727\",\"eTag\":\"0x8D619B6EB40511E\",\"lastModified\":\"2018-09-13T20:24:34.1106974Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask727\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask726\",\"eTag\":\"0x8D619B6EB41B5A4\",\"lastModified\":\"2018-09-13T20:24:34.1198244Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask726\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask725\",\"eTag\":\"0x8D619B6EB43374A\",\"lastModified\":\"2018-09-13T20:24:34.129697Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask725\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask724\",\"eTag\":\"0x8D619B6EB4CFC94\",\"lastModified\":\"2018-09-13T20:24:34.19373Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask724\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask722\",\"eTag\":\"0x8D619B6EB4F6C4D\",\"lastModified\":\"2018-09-13T20:24:34.2096973Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask722\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask721\",\"eTag\":\"0x8D619B6EB540022\",\"lastModified\":\"2018-09-13T20:24:34.2396962Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask721\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask718\",\"eTag\":\"0x8D619B6EB5538AA\",\"lastModified\":\"2018-09-13T20:24:34.247697Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask718\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask720\",\"eTag\":\"0x8D619B6EB56BF34\",\"lastModified\":\"2018-09-13T20:24:34.2576948Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask720\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask716\",\"eTag\":\"0x8D619B6EB59A6F5\",\"lastModified\":\"2018-09-13T20:24:34.2767349Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask716\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask715\",\"eTag\":\"0x8D619B6EB5D88F0\",\"lastModified\":\"2018-09-13T20:24:34.3021808Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask715\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask717\",\"eTag\":\"0x8D619B6EB616DB7\",\"lastModified\":\"2018-09-13T20:24:34.3276983Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask717\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask719\",\"eTag\":\"0x8D619B6EB581EC8\",\"lastModified\":\"2018-09-13T20:24:34.2666952Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask719\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask723\",\"eTag\":\"0x8D619B6EB56BF34\",\"lastModified\":\"2018-09-13T20:24:34.2576948Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask723\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask707\",\"eTag\":\"0x8D619B6EB66C54F\",\"lastModified\":\"2018-09-13T20:24:34.3627087Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask707\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask706\",\"eTag\":\"0x8D619B6EB695CFF\",\"lastModified\":\"2018-09-13T20:24:34.3796991Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask706\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask704\",\"eTag\":\"0x8D619B6EB6ABCE0\",\"lastModified\":\"2018-09-13T20:24:34.3887072Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask704\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask703\",\"eTag\":\"0x8D619B6EB6B0AB0\",\"lastModified\":\"2018-09-13T20:24:34.3906992Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask703\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask713\",\"eTag\":\"0x8D619B6EB5FE908\",\"lastModified\":\"2018-09-13T20:24:34.317748Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask713\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask712\",\"eTag\":\"0x8D619B6EB600E33\",\"lastModified\":\"2018-09-13T20:24:34.3186995Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask712\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask714\",\"eTag\":\"0x8D619B6EB5F7326\",\"lastModified\":\"2018-09-13T20:24:34.3147302Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask714\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask710\",\"eTag\":\"0x8D619B6EB714C42\",\"lastModified\":\"2018-09-13T20:24:34.4316994Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask710\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask708\",\"eTag\":\"0x8D619B6EB714C42\",\"lastModified\":\"2018-09-13T20:24:34.4316994Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask708\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask709\",\"eTag\":\"0x8D619B6EB6194F0\",\"lastModified\":\"2018-09-13T20:24:34.3287024Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask709\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask699\",\"eTag\":\"0x8D619B6EB70FE1C\",\"lastModified\":\"2018-09-13T20:24:34.4296988Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask699\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask698\",\"eTag\":\"0x8D619B6EB72D2E8\",\"lastModified\":\"2018-09-13T20:24:34.4417Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask698\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask695\",\"eTag\":\"0x8D619B6EB76F188\",\"lastModified\":\"2018-09-13T20:24:34.4686984Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask695\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask693\",\"eTag\":\"0x8D619B6EB773FCF\",\"lastModified\":\"2018-09-13T20:24:34.4707023Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask693\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask696\",\"eTag\":\"0x8D619B6EB76F188\",\"lastModified\":\"2018-09-13T20:24:34.4686984Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask696\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask694\",\"eTag\":\"0x8D619B6EB785110\",\"lastModified\":\"2018-09-13T20:24:34.4776976Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask694\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask705\",\"eTag\":\"0x8D619B6EB695CFF\",\"lastModified\":\"2018-09-13T20:24:34.3796991Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask705\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask691\",\"eTag\":\"0x8D619B6EB7BD374\",\"lastModified\":\"2018-09-13T20:24:34.5006964Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask691\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask692\",\"eTag\":\"0x8D619B6EB7BD374\",\"lastModified\":\"2018-09-13T20:24:34.5006964Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask692\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask690\",\"eTag\":\"0x8D619B6EB7EE0C6\",\"lastModified\":\"2018-09-13T20:24:34.5206982Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask690\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask688\",\"eTag\":\"0x8D619B6EB7EE0C6\",\"lastModified\":\"2018-09-13T20:24:34.5206982Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask688\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask689\",\"eTag\":\"0x8D619B6EB7EE0C6\",\"lastModified\":\"2018-09-13T20:24:34.5206982Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask689\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask702\",\"eTag\":\"0x8D619B6EB6DA2BB\",\"lastModified\":\"2018-09-13T20:24:34.4076987Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask702\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask711\",\"eTag\":\"0x8D619B6EB6DC9D5\",\"lastModified\":\"2018-09-13T20:24:34.4086997Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask711\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask687\",\"eTag\":\"0x8D619B6EB804046\",\"lastModified\":\"2018-09-13T20:24:34.5296966Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask687\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask700\",\"eTag\":\"0x8D619B6EB804046\",\"lastModified\":\"2018-09-13T20:24:34.5296966Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask700\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask697\",\"eTag\":\"0x8D619B6EB74326A\",\"lastModified\":\"2018-09-13T20:24:34.4506986Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask697\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask685\",\"eTag\":\"0x8D619B6EB8178E1\",\"lastModified\":\"2018-09-13T20:24:34.5376993Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask685\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask701\",\"eTag\":\"0x8D619B6EB81A2DC\",\"lastModified\":\"2018-09-13T20:24:34.538774Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask701\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask686\",\"eTag\":\"0x8D619B6EB8178E1\",\"lastModified\":\"2018-09-13T20:24:34.5376993Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask686\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask684\",\"eTag\":\"0x8D619B6EB82A5F7\",\"lastModified\":\"2018-09-13T20:24:34.5454071Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask684\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask683\",\"eTag\":\"0x8D619B6EB8374BE\",\"lastModified\":\"2018-09-13T20:24:34.5507006Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask683\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:33 GMT'] + request-id: [8d14d4bb-f326-4520-99fa-de05eb49c06d] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask632", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask631", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask630", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask629", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask628", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask627", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask626", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask625", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask624", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask623", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask622", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask621", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask620", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask619", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask618", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask617", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask616", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask615", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask614", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask613", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask612", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask611", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask610", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask609", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask608", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask607", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask606", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask605", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask604", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask603", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask602", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask601", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask600", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask599", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask598", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask597", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask596", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask595", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask594", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask593", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask592", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask591", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask590", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask589", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask588", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask587", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask586", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask585", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask584", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask583", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:34 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask632\",\"eTag\":\"0x8D619B6EC6321C6\",\"lastModified\":\"2018-09-13T20:24:36.016583Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask632\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask631\",\"eTag\":\"0x8D619B6EC648163\",\"lastModified\":\"2018-09-13T20:24:36.0255843Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask631\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask630\",\"eTag\":\"0x8D619B6EC6607FE\",\"lastModified\":\"2018-09-13T20:24:36.0355838Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask630\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask629\",\"eTag\":\"0x8D619B6EC678F79\",\"lastModified\":\"2018-09-13T20:24:36.0456057Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask629\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask628\",\"eTag\":\"0x8D619B6EC69153D\",\"lastModified\":\"2018-09-13T20:24:36.0555837Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask628\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask627\",\"eTag\":\"0x8D619B6EC6A74D6\",\"lastModified\":\"2018-09-13T20:24:36.0645846Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask627\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask626\",\"eTag\":\"0x8D619B6EC6BFB78\",\"lastModified\":\"2018-09-13T20:24:36.0745848Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask626\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask625\",\"eTag\":\"0x8D619B6EC6DAA2F\",\"lastModified\":\"2018-09-13T20:24:36.0856111Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask625\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask624\",\"eTag\":\"0x8D619B6EC6F57DF\",\"lastModified\":\"2018-09-13T20:24:36.0966111Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask624\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask622\",\"eTag\":\"0x8D619B6EC739CB8\",\"lastModified\":\"2018-09-13T20:24:36.124588Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask622\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask620\",\"eTag\":\"0x8D619B6EC7634B7\",\"lastModified\":\"2018-09-13T20:24:36.1415863Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask620\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask623\",\"eTag\":\"0x8D619B6EC78F3D2\",\"lastModified\":\"2018-09-13T20:24:36.1595858Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask623\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask621\",\"eTag\":\"0x8D619B6EC79691F\",\"lastModified\":\"2018-09-13T20:24:36.1625887Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask621\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask618\",\"eTag\":\"0x8D619B6EC79691F\",\"lastModified\":\"2018-09-13T20:24:36.1625887Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask618\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask615\",\"eTag\":\"0x8D619B6EC7C011B\",\"lastModified\":\"2018-09-13T20:24:36.1795867Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask615\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask614\",\"eTag\":\"0x8D619B6EC7D6974\",\"lastModified\":\"2018-09-13T20:24:36.1888116Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask614\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask612\",\"eTag\":\"0x8D619B6EC7F5C91\",\"lastModified\":\"2018-09-13T20:24:36.2015889Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask612\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask616\",\"eTag\":\"0x8D619B6EC7C284F\",\"lastModified\":\"2018-09-13T20:24:36.1805903Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask616\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask611\",\"eTag\":\"0x8D619B6EC8269F8\",\"lastModified\":\"2018-09-13T20:24:36.2215928Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask611\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask610\",\"eTag\":\"0x8D619B6EC83F089\",\"lastModified\":\"2018-09-13T20:24:36.2315913Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask610\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask609\",\"eTag\":\"0x8D619B6EC83F089\",\"lastModified\":\"2018-09-13T20:24:36.2315913Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask609\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask617\",\"eTag\":\"0x8D619B6EC7F359E\",\"lastModified\":\"2018-09-13T20:24:36.2005918Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask617\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask608\",\"eTag\":\"0x8D619B6EC855012\",\"lastModified\":\"2018-09-13T20:24:36.2405906Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask608\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask613\",\"eTag\":\"0x8D619B6EC7F359E\",\"lastModified\":\"2018-09-13T20:24:36.2005918Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask613\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask619\",\"eTag\":\"0x8D619B6EC7C011B\",\"lastModified\":\"2018-09-13T20:24:36.1795867Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask619\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask607\",\"eTag\":\"0x8D619B6EC86D6CC\",\"lastModified\":\"2018-09-13T20:24:36.2505932Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask607\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask605\",\"eTag\":\"0x8D619B6EC880F31\",\"lastModified\":\"2018-09-13T20:24:36.2585905Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask605\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask606\",\"eTag\":\"0x8D619B6EC883668\",\"lastModified\":\"2018-09-13T20:24:36.2595944Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask606\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask604\",\"eTag\":\"0x8D619B6EC896EC4\",\"lastModified\":\"2018-09-13T20:24:36.2675908Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask604\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask603\",\"eTag\":\"0x8D619B6EC89E414\",\"lastModified\":\"2018-09-13T20:24:36.270594Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask603\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask602\",\"eTag\":\"0x8D619B6EC8B6A9E\",\"lastModified\":\"2018-09-13T20:24:36.2805918Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask602\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask601\",\"eTag\":\"0x8D619B6EC8CF158\",\"lastModified\":\"2018-09-13T20:24:36.2905944Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask601\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask600\",\"eTag\":\"0x8D619B6EC8E50F4\",\"lastModified\":\"2018-09-13T20:24:36.2995956Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask600\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask599\",\"eTag\":\"0x8D619B6EC8F56D0\",\"lastModified\":\"2018-09-13T20:24:36.3062992Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask599\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask598\",\"eTag\":\"0x8D619B6EC8FFE9A\",\"lastModified\":\"2018-09-13T20:24:36.3105946Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask598\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask597\",\"eTag\":\"0x8D619B6EC915E37\",\"lastModified\":\"2018-09-13T20:24:36.3195959Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask597\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask596\",\"eTag\":\"0x8D619B6EC92BDC9\",\"lastModified\":\"2018-09-13T20:24:36.3285961Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask596\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask595\",\"eTag\":\"0x8D619B6EC93CF21\",\"lastModified\":\"2018-09-13T20:24:36.3355937Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask595\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask594\",\"eTag\":\"0x8D619B6EC944467\",\"lastModified\":\"2018-09-13T20:24:36.3385959Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask594\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask592\",\"eTag\":\"0x8D619B6EC9838AE\",\"lastModified\":\"2018-09-13T20:24:36.3645102Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask592\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask593\",\"eTag\":\"0x8D619B6EC98B133\",\"lastModified\":\"2018-09-13T20:24:36.3675955Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask593\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask591\",\"eTag\":\"0x8D619B6EC9B3068\",\"lastModified\":\"2018-09-13T20:24:36.3839592Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask591\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask590\",\"eTag\":\"0x8D619B6EC9B382D\",\"lastModified\":\"2018-09-13T20:24:36.3841581Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask590\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask588\",\"eTag\":\"0x8D619B6EC9CB16B\",\"lastModified\":\"2018-09-13T20:24:36.3938155Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask588\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask587\",\"eTag\":\"0x8D619B6EC9E37BF\",\"lastModified\":\"2018-09-13T20:24:36.4038079Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask587\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask586\",\"eTag\":\"0x8D619B6EC9FB8C2\",\"lastModified\":\"2018-09-13T20:24:36.4136642Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask586\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask585\",\"eTag\":\"0x8D619B6EC9FBB55\",\"lastModified\":\"2018-09-13T20:24:36.4137301Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask585\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask584\",\"eTag\":\"0x8D619B6ECA6BBB4\",\"lastModified\":\"2018-09-13T20:24:36.4596148Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask584\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask589\",\"eTag\":\"0x8D619B6ECA70984\",\"lastModified\":\"2018-09-13T20:24:36.4616068Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask589\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask583\",\"eTag\":\"0x8D619B6ECA70984\",\"lastModified\":\"2018-09-13T20:24:36.4616068Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask583\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:35 GMT'] + request-id: [49372a53-1342-4857-9191-413a96070a50] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask582", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask581", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask580", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask579", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask578", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask577", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask576", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask575", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask574", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask573", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask572", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask571", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask570", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask569", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask568", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask567", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask566", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask565", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask564", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask563", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask562", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask561", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask560", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask559", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask558", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask557", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask556", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask555", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask554", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask553", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask552", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask551", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask550", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask549", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask548", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask547", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask546", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask545", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask544", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask543", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask542", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask541", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask540", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask539", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask538", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask537", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask536", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask535", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask534", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask533", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:36 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask582\",\"eTag\":\"0x8D619B6ED8E4475\",\"lastModified\":\"2018-09-13T20:24:37.9769973Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask582\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask577\",\"eTag\":\"0x8D619B6ED9AEE55\",\"lastModified\":\"2018-09-13T20:24:38.0599893Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask577\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask581\",\"eTag\":\"0x8D619B6ED9AC732\",\"lastModified\":\"2018-09-13T20:24:38.0589874Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask581\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask578\",\"eTag\":\"0x8D619B6EDA108E4\",\"lastModified\":\"2018-09-13T20:24:38.0999908Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask578\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask572\",\"eTag\":\"0x8D619B6EDA3EF1A\",\"lastModified\":\"2018-09-13T20:24:38.1189914Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask572\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask579\",\"eTag\":\"0x8D619B6ED9B3C77\",\"lastModified\":\"2018-09-13T20:24:38.0619895Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask579\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask576\",\"eTag\":\"0x8D619B6ED9C4DD4\",\"lastModified\":\"2018-09-13T20:24:38.0689876Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask576\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask567\",\"eTag\":\"0x8D619B6EDA9E27D\",\"lastModified\":\"2018-09-13T20:24:38.1579901Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask567\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask580\",\"eTag\":\"0x8D619B6ED9B1555\",\"lastModified\":\"2018-09-13T20:24:38.0609877Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask580\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask573\",\"eTag\":\"0x8D619B6ED9F8234\",\"lastModified\":\"2018-09-13T20:24:38.0899892Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask573\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask566\",\"eTag\":\"0x8D619B6EDAB4222\",\"lastModified\":\"2018-09-13T20:24:38.1669922Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask566\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask571\",\"eTag\":\"0x8D619B6EDA41627\",\"lastModified\":\"2018-09-13T20:24:38.1199911Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask571\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask564\",\"eTag\":\"0x8D619B6EDAE7668\",\"lastModified\":\"2018-09-13T20:24:38.1879912Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask564\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask563\",\"eTag\":\"0x8D619B6EDB1358A\",\"lastModified\":\"2018-09-13T20:24:38.2059914Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask563\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask575\",\"eTag\":\"0x8D619B6EDA54E91\",\"lastModified\":\"2018-09-13T20:24:38.1279889Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask575\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask574\",\"eTag\":\"0x8D619B6EDA9E27D\",\"lastModified\":\"2018-09-13T20:24:38.1579901Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask574\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask570\",\"eTag\":\"0x8D619B6EDA6AF99\",\"lastModified\":\"2018-09-13T20:24:38.1370265Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask570\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask562\",\"eTag\":\"0x8D619B6EDB30A50\",\"lastModified\":\"2018-09-13T20:24:38.217992Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask562\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask565\",\"eTag\":\"0x8D619B6EDAE9D85\",\"lastModified\":\"2018-09-13T20:24:38.1889925Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask565\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask568\",\"eTag\":\"0x8D619B6EDAA09B6\",\"lastModified\":\"2018-09-13T20:24:38.1589942Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask568\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask569\",\"eTag\":\"0x8D619B6EDA59CC3\",\"lastModified\":\"2018-09-13T20:24:38.1299907Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask569\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask561\",\"eTag\":\"0x8D619B6EDB41C64\",\"lastModified\":\"2018-09-13T20:24:38.2250084Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask561\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask560\",\"eTag\":\"0x8D619B6EDB442E0\",\"lastModified\":\"2018-09-13T20:24:38.2259936Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask560\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask559\",\"eTag\":\"0x8D619B6EDB4B813\",\"lastModified\":\"2018-09-13T20:24:38.2289939Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask559\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask558\",\"eTag\":\"0x8D619B6EDB7210A\",\"lastModified\":\"2018-09-13T20:24:38.2447882Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask558\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask557\",\"eTag\":\"0x8D619B6EDB8AFA4\",\"lastModified\":\"2018-09-13T20:24:38.2549924Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask557\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask555\",\"eTag\":\"0x8D619B6EDBDB8D6\",\"lastModified\":\"2018-09-13T20:24:38.2879958Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask555\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask556\",\"eTag\":\"0x8D619B6EDBD91C2\",\"lastModified\":\"2018-09-13T20:24:38.2869954Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask556\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask554\",\"eTag\":\"0x8D619B6EDC050D0\",\"lastModified\":\"2018-09-13T20:24:38.3049936Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask554\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask553\",\"eTag\":\"0x8D619B6EDC0C62A\",\"lastModified\":\"2018-09-13T20:24:38.3079978Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask553\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask551\",\"eTag\":\"0x8D619B6EDC4BA02\",\"lastModified\":\"2018-09-13T20:24:38.333901Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask551\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask550\",\"eTag\":\"0x8D619B6EDC63DA9\",\"lastModified\":\"2018-09-13T20:24:38.3438249Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask550\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask547\",\"eTag\":\"0x8D619B6EDCAC0D5\",\"lastModified\":\"2018-09-13T20:24:38.3733973Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask547\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask548\",\"eTag\":\"0x8D619B6EDCB4D8A\",\"lastModified\":\"2018-09-13T20:24:38.3769994Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask548\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask552\",\"eTag\":\"0x8D619B6EDCAC895\",\"lastModified\":\"2018-09-13T20:24:38.3735957Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask552\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask549\",\"eTag\":\"0x8D619B6EDCB2673\",\"lastModified\":\"2018-09-13T20:24:38.3759987Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask549\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask546\",\"eTag\":\"0x8D619B6EDCC41D1\",\"lastModified\":\"2018-09-13T20:24:38.3832529Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask546\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask544\",\"eTag\":\"0x8D619B6EDCDBE87\",\"lastModified\":\"2018-09-13T20:24:38.3929991Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask544\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask545\",\"eTag\":\"0x8D619B6EDCCD43F\",\"lastModified\":\"2018-09-13T20:24:38.3870015Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask545\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask541\",\"eTag\":\"0x8D619B6EDD14107\",\"lastModified\":\"2018-09-13T20:24:38.4160007Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask541\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask542\",\"eTag\":\"0x8D619B6EDCFBA59\",\"lastModified\":\"2018-09-13T20:24:38.4059993Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask542\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask543\",\"eTag\":\"0x8D619B6EDCE5ACA\",\"lastModified\":\"2018-09-13T20:24:38.3969994Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask543\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask540\",\"eTag\":\"0x8D619B6EDD42715\",\"lastModified\":\"2018-09-13T20:24:38.4349973Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask540\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask539\",\"eTag\":\"0x8D619B6EDD5AE32\",\"lastModified\":\"2018-09-13T20:24:38.4450098Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask539\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask538\",\"eTag\":\"0x8D619B6EDD70D4A\",\"lastModified\":\"2018-09-13T20:24:38.4539978Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask538\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask537\",\"eTag\":\"0x8D619B6EDD893EC\",\"lastModified\":\"2018-09-13T20:24:38.463998Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask537\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask536\",\"eTag\":\"0x8D619B6EDDA41A1\",\"lastModified\":\"2018-09-13T20:24:38.4749985Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask536\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask535\",\"eTag\":\"0x8D619B6EDDB7A23\",\"lastModified\":\"2018-09-13T20:24:38.4829987Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask535\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask534\",\"eTag\":\"0x8D619B6EDDCD9C6\",\"lastModified\":\"2018-09-13T20:24:38.4920006Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask534\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask533\",\"eTag\":\"0x8D619B6EDDEFDA8\",\"lastModified\":\"2018-09-13T20:24:38.5060264Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask533\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:38 GMT'] + request-id: [39b94660-280d-4c8c-a289-ffb177b829b5] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask532", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask531", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask530", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask529", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask528", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask527", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask526", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask525", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask524", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask523", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask522", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask521", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask520", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask519", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask518", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask517", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask516", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask515", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask514", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask513", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask512", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask511", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask510", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask509", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask508", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask507", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask506", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask505", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask504", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask503", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask502", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask501", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask500", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask499", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask498", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask497", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask496", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask495", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask494", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask493", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask492", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask491", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask490", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask489", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask488", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask487", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask486", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask485", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask484", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask483", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:38 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask532\",\"eTag\":\"0x8D619B6EECE012C\",\"lastModified\":\"2018-09-13T20:24:40.0724268Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask532\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask531\",\"eTag\":\"0x8D619B6EECF87AC\",\"lastModified\":\"2018-09-13T20:24:40.0824236Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask531\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask530\",\"eTag\":\"0x8D619B6EED13572\",\"lastModified\":\"2018-09-13T20:24:40.0934258Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask530\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask529\",\"eTag\":\"0x8D619B6EED3A77D\",\"lastModified\":\"2018-09-13T20:24:40.1094525Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask529\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask528\",\"eTag\":\"0x8D619B6EED52E9F\",\"lastModified\":\"2018-09-13T20:24:40.1194655Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask528\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask527\",\"eTag\":\"0x8D619B6EED5C954\",\"lastModified\":\"2018-09-13T20:24:40.123426Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask527\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask526\",\"eTag\":\"0x8D619B6EED728FB\",\"lastModified\":\"2018-09-13T20:24:40.1324283Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask526\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask525\",\"eTag\":\"0x8D619B6EED8D69E\",\"lastModified\":\"2018-09-13T20:24:40.143427Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask525\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask524\",\"eTag\":\"0x8D619B6EEDBBCDD\",\"lastModified\":\"2018-09-13T20:24:40.1624285Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask524\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask523\",\"eTag\":\"0x8D619B6EEDD1C6B\",\"lastModified\":\"2018-09-13T20:24:40.1714283Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask523\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask521\",\"eTag\":\"0x8D619B6EEDFDBA5\",\"lastModified\":\"2018-09-13T20:24:40.1894309Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask521\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask518\",\"eTag\":\"0x8D619B6EEE2E8CF\",\"lastModified\":\"2018-09-13T20:24:40.2094287Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask518\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask522\",\"eTag\":\"0x8D619B6EEE2E8CF\",\"lastModified\":\"2018-09-13T20:24:40.2094287Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask522\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask515\",\"eTag\":\"0x8D619B6EEE5A808\",\"lastModified\":\"2018-09-13T20:24:40.2274312Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask515\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask520\",\"eTag\":\"0x8D619B6EEE49694\",\"lastModified\":\"2018-09-13T20:24:40.2204308Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask520\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask519\",\"eTag\":\"0x8D619B6EEE92B62\",\"lastModified\":\"2018-09-13T20:24:40.2504546Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask519\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask514\",\"eTag\":\"0x8D619B6EEE7A3E7\",\"lastModified\":\"2018-09-13T20:24:40.2404327Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask514\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask517\",\"eTag\":\"0x8D619B6EEE97894\",\"lastModified\":\"2018-09-13T20:24:40.2524308Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask517\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask516\",\"eTag\":\"0x8D619B6EEF5117D\",\"lastModified\":\"2018-09-13T20:24:40.3284349Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask516\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask510\",\"eTag\":\"0x8D619B6EEF67116\",\"lastModified\":\"2018-09-13T20:24:40.3374358Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask510\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask498\",\"eTag\":\"0x8D619B6EEFF9902\",\"lastModified\":\"2018-09-13T20:24:40.3974402Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask498\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask496\",\"eTag\":\"0x8D619B6EF024AE0\",\"lastModified\":\"2018-09-13T20:24:40.4151008Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask496\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask512\",\"eTag\":\"0x8D619B6EEE97894\",\"lastModified\":\"2018-09-13T20:24:40.2524308Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask512\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask513\",\"eTag\":\"0x8D619B6EEEAB109\",\"lastModified\":\"2018-09-13T20:24:40.2604297Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask513\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask509\",\"eTag\":\"0x8D619B6EEF69828\",\"lastModified\":\"2018-09-13T20:24:40.338436Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask509\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask506\",\"eTag\":\"0x8D619B6EEF845EC\",\"lastModified\":\"2018-09-13T20:24:40.349438Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask506\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask508\",\"eTag\":\"0x8D619B6EEF81ED6\",\"lastModified\":\"2018-09-13T20:24:40.3484374Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask508\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask507\",\"eTag\":\"0x8D619B6EEF7F7C2\",\"lastModified\":\"2018-09-13T20:24:40.347437Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask507\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask483\",\"eTag\":\"0x8D619B6EF0E8D4F\",\"lastModified\":\"2018-09-13T20:24:40.4954447Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask483\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask485\",\"eTag\":\"0x8D619B6EF0E8D4F\",\"lastModified\":\"2018-09-13T20:24:40.4954447Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask485\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask486\",\"eTag\":\"0x8D619B6EF0E6D46\",\"lastModified\":\"2018-09-13T20:24:40.4946246Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask486\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask497\",\"eTag\":\"0x8D619B6EEFF9902\",\"lastModified\":\"2018-09-13T20:24:40.3974402Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask497\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask511\",\"eTag\":\"0x8D619B6EF0E6819\",\"lastModified\":\"2018-09-13T20:24:40.4944921Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask511\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask495\",\"eTag\":\"0x8D619B6EF03DEC2\",\"lastModified\":\"2018-09-13T20:24:40.4254402Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask495\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask487\",\"eTag\":\"0x8D619B6EF0D54CF\",\"lastModified\":\"2018-09-13T20:24:40.4874447Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask487\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask493\",\"eTag\":\"0x8D619B6EF0554C3\",\"lastModified\":\"2018-09-13T20:24:40.4350147Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask493\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask492\",\"eTag\":\"0x8D619B6EF11C1A7\",\"lastModified\":\"2018-09-13T20:24:40.5164455Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask492\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask491\",\"eTag\":\"0x8D619B6EF11C1A7\",\"lastModified\":\"2018-09-13T20:24:40.5164455Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask491\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask494\",\"eTag\":\"0x8D619B6EF03DEC2\",\"lastModified\":\"2018-09-13T20:24:40.4254402Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask494\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask490\",\"eTag\":\"0x8D619B6EF12FA12\",\"lastModified\":\"2018-09-13T20:24:40.5244434Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask490\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask488\",\"eTag\":\"0x8D619B6EF076165\",\"lastModified\":\"2018-09-13T20:24:40.4484453Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask488\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask489\",\"eTag\":\"0x8D619B6EF14A7D5\",\"lastModified\":\"2018-09-13T20:24:40.5354453Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask489\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask504\",\"eTag\":\"0x8D619B6EF0EDB7A\",\"lastModified\":\"2018-09-13T20:24:40.4974458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask504\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask484\",\"eTag\":\"0x8D619B6EF0EB46A\",\"lastModified\":\"2018-09-13T20:24:40.4964458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask484\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask499\",\"eTag\":\"0x8D619B6EF0EDB7A\",\"lastModified\":\"2018-09-13T20:24:40.4974458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask499\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask500\",\"eTag\":\"0x8D619B6EF0EDB7A\",\"lastModified\":\"2018-09-13T20:24:40.4974458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask500\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask502\",\"eTag\":\"0x8D619B6EF0EB46A\",\"lastModified\":\"2018-09-13T20:24:40.4964458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask502\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask505\",\"eTag\":\"0x8D619B6EF0E8D4F\",\"lastModified\":\"2018-09-13T20:24:40.4954447Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask505\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask501\",\"eTag\":\"0x8D619B6EF0EB46A\",\"lastModified\":\"2018-09-13T20:24:40.4964458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask501\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask503\",\"eTag\":\"0x8D619B6EF0EB46A\",\"lastModified\":\"2018-09-13T20:24:40.4964458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask503\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:40 GMT'] + request-id: [4ebdc2d7-d10d-4e0b-b1ef-8983174c9655] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask482", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask481", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask480", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask479", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask478", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask477", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask476", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask475", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask474", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask473", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask472", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask471", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask470", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask469", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask468", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask467", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask466", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask465", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask464", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask463", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask462", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask461", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask460", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask459", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask458", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask457", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask456", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask455", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask454", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask453", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask452", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask451", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask450", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask449", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask448", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask447", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask446", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask445", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask444", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask443", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask442", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask441", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask440", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask439", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask438", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask437", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask436", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask435", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask434", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask433", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:40 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask481\",\"eTag\":\"0x8D619B6F00A1859\",\"lastModified\":\"2018-09-13T20:24:42.1439577Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask481\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask482\",\"eTag\":\"0x8D619B6F00A1859\",\"lastModified\":\"2018-09-13T20:24:42.1439577Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask482\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask480\",\"eTag\":\"0x8D619B6F00B77CD\",\"lastModified\":\"2018-09-13T20:24:42.1529549Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask480\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask479\",\"eTag\":\"0x8D619B6F00CFE84\",\"lastModified\":\"2018-09-13T20:24:42.1629572Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask479\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask478\",\"eTag\":\"0x8D619B6F00CFE84\",\"lastModified\":\"2018-09-13T20:24:42.1629572Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask478\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask477\",\"eTag\":\"0x8D619B6F00FBDB5\",\"lastModified\":\"2018-09-13T20:24:42.1809589Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask477\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask476\",\"eTag\":\"0x8D619B6F0100BBE\",\"lastModified\":\"2018-09-13T20:24:42.1829566Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask476\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask475\",\"eTag\":\"0x8D619B6F0119271\",\"lastModified\":\"2018-09-13T20:24:42.1929585Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask475\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask474\",\"eTag\":\"0x8D619B6F0119271\",\"lastModified\":\"2018-09-13T20:24:42.1929585Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask474\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask473\",\"eTag\":\"0x8D619B6F0131928\",\"lastModified\":\"2018-09-13T20:24:42.2029608Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask473\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask472\",\"eTag\":\"0x8D619B6F0131928\",\"lastModified\":\"2018-09-13T20:24:42.2029608Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask472\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask471\",\"eTag\":\"0x8D619B6F0149FAF\",\"lastModified\":\"2018-09-13T20:24:42.2129583Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask471\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask470\",\"eTag\":\"0x8D619B6F016265F\",\"lastModified\":\"2018-09-13T20:24:42.2229599Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask470\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask469\",\"eTag\":\"0x8D619B6F016265F\",\"lastModified\":\"2018-09-13T20:24:42.2229599Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask469\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask468\",\"eTag\":\"0x8D619B6F018BE7D\",\"lastModified\":\"2018-09-13T20:24:42.2399613Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask468\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask467\",\"eTag\":\"0x8D619B6F01A79B3\",\"lastModified\":\"2018-09-13T20:24:42.2513075Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask467\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask465\",\"eTag\":\"0x8D619B6F01ABA68\",\"lastModified\":\"2018-09-13T20:24:42.252964Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask465\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask466\",\"eTag\":\"0x8D619B6F01A9350\",\"lastModified\":\"2018-09-13T20:24:42.2519632Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask466\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask464\",\"eTag\":\"0x8D619B6F01BD3F1\",\"lastModified\":\"2018-09-13T20:24:42.2601713Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask464\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask463\",\"eTag\":\"0x8D619B6F01C6817\",\"lastModified\":\"2018-09-13T20:24:42.2639639Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask463\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask462\",\"eTag\":\"0x8D619B6F01D526C\",\"lastModified\":\"2018-09-13T20:24:42.2699628Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask462\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask461\",\"eTag\":\"0x8D619B6F01DEE9E\",\"lastModified\":\"2018-09-13T20:24:42.2739614Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask461\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask460\",\"eTag\":\"0x8D619B6F01F7564\",\"lastModified\":\"2018-09-13T20:24:42.2839652Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask460\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask459\",\"eTag\":\"0x8D619B6F01F7564\",\"lastModified\":\"2018-09-13T20:24:42.2839652Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask459\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask458\",\"eTag\":\"0x8D619B6F0212305\",\"lastModified\":\"2018-09-13T20:24:42.2949637Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask458\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask457\",\"eTag\":\"0x8D619B6F0220D77\",\"lastModified\":\"2018-09-13T20:24:42.3009655Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask457\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask456\",\"eTag\":\"0x8D619B6F022829E\",\"lastModified\":\"2018-09-13T20:24:42.3039646Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask456\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask454\",\"eTag\":\"0x8D619B6F02541F4\",\"lastModified\":\"2018-09-13T20:24:42.32197Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask454\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask455\",\"eTag\":\"0x8D619B6F0251CA0\",\"lastModified\":\"2018-09-13T20:24:42.3210144Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask455\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask453\",\"eTag\":\"0x8D619B6F025DEFD\",\"lastModified\":\"2018-09-13T20:24:42.3259901Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask453\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask452\",\"eTag\":\"0x8D619B6F026A154\",\"lastModified\":\"2018-09-13T20:24:42.3309652Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask452\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask451\",\"eTag\":\"0x8D619B6F026EFA8\",\"lastModified\":\"2018-09-13T20:24:42.3329704Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask451\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask450\",\"eTag\":\"0x8D619B6F02800E5\",\"lastModified\":\"2018-09-13T20:24:42.3399653Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask450\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask449\",\"eTag\":\"0x8D619B6F0296265\",\"lastModified\":\"2018-09-13T20:24:42.3490149Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask449\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask447\",\"eTag\":\"0x8D619B6F02AE810\",\"lastModified\":\"2018-09-13T20:24:42.3589904Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask447\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask448\",\"eTag\":\"0x8D619B6F02AE810\",\"lastModified\":\"2018-09-13T20:24:42.3589904Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask448\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask446\",\"eTag\":\"0x8D619B6F02C6DD5\",\"lastModified\":\"2018-09-13T20:24:42.3689685Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask446\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask445\",\"eTag\":\"0x8D619B6F02D310F\",\"lastModified\":\"2018-09-13T20:24:42.3739663Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask445\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask444\",\"eTag\":\"0x8D619B6F02E2C07\",\"lastModified\":\"2018-09-13T20:24:42.3803911Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask444\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask442\",\"eTag\":\"0x8D619B6F02FA416\",\"lastModified\":\"2018-09-13T20:24:42.3900182Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask442\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask443\",\"eTag\":\"0x8D619B6F02FA416\",\"lastModified\":\"2018-09-13T20:24:42.3900182Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask443\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask441\",\"eTag\":\"0x8D619B6F03129FE\",\"lastModified\":\"2018-09-13T20:24:42.3999998Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask441\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask440\",\"eTag\":\"0x8D619B6F031C51F\",\"lastModified\":\"2018-09-13T20:24:42.4039711Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask440\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask439\",\"eTag\":\"0x8D619B6F032B9A9\",\"lastModified\":\"2018-09-13T20:24:42.4102313Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask439\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask438\",\"eTag\":\"0x8D619B6F0343648\",\"lastModified\":\"2018-09-13T20:24:42.4199752Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask438\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask437\",\"eTag\":\"0x8D619B6F034D251\",\"lastModified\":\"2018-09-13T20:24:42.4239697Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask437\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask435\",\"eTag\":\"0x8D619B6F037438F\",\"lastModified\":\"2018-09-13T20:24:42.4399759Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask435\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask436\",\"eTag\":\"0x8D619B6F037438F\",\"lastModified\":\"2018-09-13T20:24:42.4399759Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask436\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask434\",\"eTag\":\"0x8D619B6F037DF90\",\"lastModified\":\"2018-09-13T20:24:42.4439696Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask434\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask433\",\"eTag\":\"0x8D619B6F0398FBC\",\"lastModified\":\"2018-09-13T20:24:42.4550332Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask433\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:41 GMT'] + request-id: [514f6cb2-e9a2-440f-88b4-433e8397bc8b] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask432", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask431", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask430", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask429", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask428", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask427", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask426", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask425", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask424", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask423", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask422", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask421", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask420", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask419", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask418", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask417", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask416", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask415", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask414", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask413", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask412", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask411", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask410", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask409", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask408", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask407", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask406", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask405", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask404", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask403", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask402", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask401", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask400", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask399", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask398", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask397", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask396", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask395", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask394", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask393", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask392", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask391", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask390", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask389", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask388", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask387", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask386", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask385", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask384", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask383", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:42 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask432\",\"eTag\":\"0x8D619B6F129333A\",\"lastModified\":\"2018-09-13T20:24:44.025529Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask432\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask430\",\"eTag\":\"0x8D619B6F131229E\",\"lastModified\":\"2018-09-13T20:24:44.0775326Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask430\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask428\",\"eTag\":\"0x8D619B6F133BAA3\",\"lastModified\":\"2018-09-13T20:24:44.0945315Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask428\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask431\",\"eTag\":\"0x8D619B6F133939C\",\"lastModified\":\"2018-09-13T20:24:44.0935324Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask431\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask427\",\"eTag\":\"0x8D619B6F137160E\",\"lastModified\":\"2018-09-13T20:24:44.1165326Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask427\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask425\",\"eTag\":\"0x8D619B6F13C1F25\",\"lastModified\":\"2018-09-13T20:24:44.1495333Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask425\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask421\",\"eTag\":\"0x8D619B6F13F055E\",\"lastModified\":\"2018-09-13T20:24:44.1685342Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask421\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask424\",\"eTag\":\"0x8D619B6F13A716C\",\"lastModified\":\"2018-09-13T20:24:44.1385324Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask424\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask429\",\"eTag\":\"0x8D619B6F136EEDE\",\"lastModified\":\"2018-09-13T20:24:44.1155294Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask429\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask418\",\"eTag\":\"0x8D619B6F141D2FB\",\"lastModified\":\"2018-09-13T20:24:44.1869051Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask418\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask417\",\"eTag\":\"0x8D619B6F14212A6\",\"lastModified\":\"2018-09-13T20:24:44.188535Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask417\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask423\",\"eTag\":\"0x8D619B6F1454901\",\"lastModified\":\"2018-09-13T20:24:44.2095873Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask423\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask426\",\"eTag\":\"0x8D619B6F13DA5B6\",\"lastModified\":\"2018-09-13T20:24:44.1595318Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask426\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask422\",\"eTag\":\"0x8D619B6F147D493\",\"lastModified\":\"2018-09-13T20:24:44.2262675Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask422\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask413\",\"eTag\":\"0x8D619B6F14965AE\",\"lastModified\":\"2018-09-13T20:24:44.2365358Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask413\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask419\",\"eTag\":\"0x8D619B6F141EB9A\",\"lastModified\":\"2018-09-13T20:24:44.1875354Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask419\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask410\",\"eTag\":\"0x8D619B6F14B3A67\",\"lastModified\":\"2018-09-13T20:24:44.2485351Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask410\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask409\",\"eTag\":\"0x8D619B6F14B618D\",\"lastModified\":\"2018-09-13T20:24:44.2495373Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask409\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask420\",\"eTag\":\"0x8D619B6F148543D\",\"lastModified\":\"2018-09-13T20:24:44.2295357Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask420\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask416\",\"eTag\":\"0x8D619B6F14D5D54\",\"lastModified\":\"2018-09-13T20:24:44.2625364Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask416\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask407\",\"eTag\":\"0x8D619B6F159E3B8\",\"lastModified\":\"2018-09-13T20:24:44.34462Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask407\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask412\",\"eTag\":\"0x8D619B6F15A07B6\",\"lastModified\":\"2018-09-13T20:24:44.3455414Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask412\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask406\",\"eTag\":\"0x8D619B6F15A55D3\",\"lastModified\":\"2018-09-13T20:24:44.3475411Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask406\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask408\",\"eTag\":\"0x8D619B6F15A55D3\",\"lastModified\":\"2018-09-13T20:24:44.3475411Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask408\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask415\",\"eTag\":\"0x8D619B6F159DBE9\",\"lastModified\":\"2018-09-13T20:24:44.3444201Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask415\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask414\",\"eTag\":\"0x8D619B6F1498CCB\",\"lastModified\":\"2018-09-13T20:24:44.2375371Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask414\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask403\",\"eTag\":\"0x8D619B6F15BB569\",\"lastModified\":\"2018-09-13T20:24:44.3565417Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask403\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask411\",\"eTag\":\"0x8D619B6F149B3DF\",\"lastModified\":\"2018-09-13T20:24:44.2385375Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask411\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask394\",\"eTag\":\"0x8D619B6F162E168\",\"lastModified\":\"2018-09-13T20:24:44.4035432Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask394\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask391\",\"eTag\":\"0x8D619B6F1648F16\",\"lastModified\":\"2018-09-13T20:24:44.414543Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask391\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask392\",\"eTag\":\"0x8D619B6F164DD45\",\"lastModified\":\"2018-09-13T20:24:44.4165445Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask392\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask393\",\"eTag\":\"0x8D619B6F163568C\",\"lastModified\":\"2018-09-13T20:24:44.406542Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask393\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask390\",\"eTag\":\"0x8D619B6F1679C65\",\"lastModified\":\"2018-09-13T20:24:44.4345445Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask390\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask389\",\"eTag\":\"0x8D619B6F167EA86\",\"lastModified\":\"2018-09-13T20:24:44.4365446Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask389\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask386\",\"eTag\":\"0x8D619B6F16BF04B\",\"lastModified\":\"2018-09-13T20:24:44.4629067Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask386\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask397\",\"eTag\":\"0x8D619B6F1697132\",\"lastModified\":\"2018-09-13T20:24:44.4465458Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask397\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask398\",\"eTag\":\"0x8D619B6F16AD0AE\",\"lastModified\":\"2018-09-13T20:24:44.4555438Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask398\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask387\",\"eTag\":\"0x8D619B6F16C0940\",\"lastModified\":\"2018-09-13T20:24:44.4635456Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask387\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask395\",\"eTag\":\"0x8D619B6F15BDC7D\",\"lastModified\":\"2018-09-13T20:24:44.3575421Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask395\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask400\",\"eTag\":\"0x8D619B6F16AF7CB\",\"lastModified\":\"2018-09-13T20:24:44.4565451Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask400\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask388\",\"eTag\":\"0x8D619B6F1694A0A\",\"lastModified\":\"2018-09-13T20:24:44.4455434Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask388\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask384\",\"eTag\":\"0x8D619B6F16DDE06\",\"lastModified\":\"2018-09-13T20:24:44.4755462Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask384\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask404\",\"eTag\":\"0x8D619B6F15CDE09\",\"lastModified\":\"2018-09-13T20:24:44.3641353Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask404\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask405\",\"eTag\":\"0x8D619B6F161A8DF\",\"lastModified\":\"2018-09-13T20:24:44.3955423Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask405\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask401\",\"eTag\":\"0x8D619B6F16C0940\",\"lastModified\":\"2018-09-13T20:24:44.4635456Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask401\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask399\",\"eTag\":\"0x8D619B6F16C3050\",\"lastModified\":\"2018-09-13T20:24:44.4645456Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask399\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask402\",\"eTag\":\"0x8D619B6F16E051B\",\"lastModified\":\"2018-09-13T20:24:44.4765467Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask402\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask385\",\"eTag\":\"0x8D619B6F16C5767\",\"lastModified\":\"2018-09-13T20:24:44.4655463Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask385\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask383\",\"eTag\":\"0x8D619B6F1707601\",\"lastModified\":\"2018-09-13T20:24:44.4925441Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask383\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask396\",\"eTag\":\"0x8D619B6F16C3050\",\"lastModified\":\"2018-09-13T20:24:44.4645456Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask396\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:44 GMT'] + request-id: [aed51892-92af-4870-afc1-19906e525c5a] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask382", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask381", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask380", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask379", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask378", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask377", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask376", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask375", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask374", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask373", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask372", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask371", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask370", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask369", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask368", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask367", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask366", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask365", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask364", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask363", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask362", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask361", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask360", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask359", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask358", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask357", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask356", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask355", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask354", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask353", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask352", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask351", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask350", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask349", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask348", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask347", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask346", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask345", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask344", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask343", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask342", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask341", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask340", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask339", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask338", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask337", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask336", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask335", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask334", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask333", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:44 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask382\",\"eTag\":\"0x8D619B6F26E6F93\",\"lastModified\":\"2018-09-13T20:24:46.1569939Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask382\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask381\",\"eTag\":\"0x8D619B6F2701AC4\",\"lastModified\":\"2018-09-13T20:24:46.16793Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask381\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask379\",\"eTag\":\"0x8D619B6F2739D45\",\"lastModified\":\"2018-09-13T20:24:46.1909317Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask379\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask380\",\"eTag\":\"0x8D619B6F274FCDF\",\"lastModified\":\"2018-09-13T20:24:46.1999327Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask380\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask377\",\"eTag\":\"0x8D619B6F276386C\",\"lastModified\":\"2018-09-13T20:24:46.2080108Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask377\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask378\",\"eTag\":\"0x8D619B6F2768361\",\"lastModified\":\"2018-09-13T20:24:46.2099297Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask378\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask373\",\"eTag\":\"0x8D619B6F27D8865\",\"lastModified\":\"2018-09-13T20:24:46.2559333Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask373\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask375\",\"eTag\":\"0x8D619B6F279DF0B\",\"lastModified\":\"2018-09-13T20:24:46.2319371Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask375\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask374\",\"eTag\":\"0x8D619B6F27C77C7\",\"lastModified\":\"2018-09-13T20:24:46.2489543Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask374\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask376\",\"eTag\":\"0x8D619B6F277AC76\",\"lastModified\":\"2018-09-13T20:24:46.217535Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask376\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask372\",\"eTag\":\"0x8D619B6F27D8865\",\"lastModified\":\"2018-09-13T20:24:46.2559333Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask372\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask370\",\"eTag\":\"0x8D619B6F27EE7FE\",\"lastModified\":\"2018-09-13T20:24:46.2649342Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask370\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask363\",\"eTag\":\"0x8D619B6F288AC23\",\"lastModified\":\"2018-09-13T20:24:46.3289379Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask363\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask371\",\"eTag\":\"0x8D619B6F28884F9\",\"lastModified\":\"2018-09-13T20:24:46.3279353Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask371\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask366\",\"eTag\":\"0x8D619B6F2886BFA\",\"lastModified\":\"2018-09-13T20:24:46.3272954Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask366\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask364\",\"eTag\":\"0x8D619B6F28884F9\",\"lastModified\":\"2018-09-13T20:24:46.3279353Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask364\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask369\",\"eTag\":\"0x8D619B6F280478F\",\"lastModified\":\"2018-09-13T20:24:46.2739343Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask369\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask367\",\"eTag\":\"0x8D619B6F28354D8\",\"lastModified\":\"2018-09-13T20:24:46.2939352Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask367\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask360\",\"eTag\":\"0x8D619B6F28CD92E\",\"lastModified\":\"2018-09-13T20:24:46.3563054Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask360\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask361\",\"eTag\":\"0x8D619B6F28CB353\",\"lastModified\":\"2018-09-13T20:24:46.3553363Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask361\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask368\",\"eTag\":\"0x8D619B6F28354D8\",\"lastModified\":\"2018-09-13T20:24:46.2939352Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask368\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask365\",\"eTag\":\"0x8D619B6F28E2753\",\"lastModified\":\"2018-09-13T20:24:46.3648595Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask365\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask358\",\"eTag\":\"0x8D619B6F28E5182\",\"lastModified\":\"2018-09-13T20:24:46.3659394Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask358\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask359\",\"eTag\":\"0x8D619B6F28D4022\",\"lastModified\":\"2018-09-13T20:24:46.358941Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask359\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask356\",\"eTag\":\"0x8D619B6F28FB107\",\"lastModified\":\"2018-09-13T20:24:46.3749383Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask356\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask357\",\"eTag\":\"0x8D619B6F28F9638\",\"lastModified\":\"2018-09-13T20:24:46.374252Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask357\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask355\",\"eTag\":\"0x8D619B6F291109E\",\"lastModified\":\"2018-09-13T20:24:46.383939Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask355\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask362\",\"eTag\":\"0x8D619B6F29137AD\",\"lastModified\":\"2018-09-13T20:24:46.3849389Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask362\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask353\",\"eTag\":\"0x8D619B6F2927686\",\"lastModified\":\"2018-09-13T20:24:46.3931014Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask353\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask354\",\"eTag\":\"0x8D619B6F292714E\",\"lastModified\":\"2018-09-13T20:24:46.3929678Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask354\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask352\",\"eTag\":\"0x8D619B6F293E547\",\"lastModified\":\"2018-09-13T20:24:46.4024903Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask352\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask351\",\"eTag\":\"0x8D619B6F2955651\",\"lastModified\":\"2018-09-13T20:24:46.4119377Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask351\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask350\",\"eTag\":\"0x8D619B6F296C321\",\"lastModified\":\"2018-09-13T20:24:46.4212769Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask350\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask349\",\"eTag\":\"0x8D619B6F29863BF\",\"lastModified\":\"2018-09-13T20:24:46.4319423Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask349\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask348\",\"eTag\":\"0x8D619B6F299A33B\",\"lastModified\":\"2018-09-13T20:24:46.4401211Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask348\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask347\",\"eTag\":\"0x8D619B6F299A86D\",\"lastModified\":\"2018-09-13T20:24:46.4402541Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask347\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask345\",\"eTag\":\"0x8D619B6F29B9810\",\"lastModified\":\"2018-09-13T20:24:46.4529424Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask345\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask346\",\"eTag\":\"0x8D619B6F29B9810\",\"lastModified\":\"2018-09-13T20:24:46.4529424Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask346\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask344\",\"eTag\":\"0x8D619B6F29D9C2A\",\"lastModified\":\"2018-09-13T20:24:46.4661546Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask344\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask343\",\"eTag\":\"0x8D619B6F29E7E46\",\"lastModified\":\"2018-09-13T20:24:46.471943Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask343\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask342\",\"eTag\":\"0x8D619B6F29F70DA\",\"lastModified\":\"2018-09-13T20:24:46.478153Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask342\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask340\",\"eTag\":\"0x8D619B6F2A004F4\",\"lastModified\":\"2018-09-13T20:24:46.4819444Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask340\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask341\",\"eTag\":\"0x8D619B6F29FDFB9\",\"lastModified\":\"2018-09-13T20:24:46.4809913Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask341\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask339\",\"eTag\":\"0x8D619B6F2A0DFA1\",\"lastModified\":\"2018-09-13T20:24:46.4875425Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask339\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask338\",\"eTag\":\"0x8D619B6F2A258DD\",\"lastModified\":\"2018-09-13T20:24:46.4971997Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask338\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask337\",\"eTag\":\"0x8D619B6F2A275E4\",\"lastModified\":\"2018-09-13T20:24:46.4979428Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask337\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask336\",\"eTag\":\"0x8D619B6F2A3C51A\",\"lastModified\":\"2018-09-13T20:24:46.5065242Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask336\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask335\",\"eTag\":\"0x8D619B6F2A53BC2\",\"lastModified\":\"2018-09-13T20:24:46.5161154Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask335\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask334\",\"eTag\":\"0x8D619B6F2A6B50D\",\"lastModified\":\"2018-09-13T20:24:46.5257741Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask334\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask333\",\"eTag\":\"0x8D619B6F2A7AE32\",\"lastModified\":\"2018-09-13T20:24:46.5321522Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask333\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:46 GMT'] + request-id: [82513418-b0f7-4f5b-94f6-196c9a2d3b25] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask332", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask331", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask330", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask329", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask328", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask327", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask326", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask325", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask324", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask323", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask322", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask321", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask320", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask319", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask318", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask317", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask316", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask315", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask314", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask313", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask312", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask311", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask310", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask309", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask308", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask307", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask306", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask305", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask304", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask303", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask302", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask301", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask300", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask299", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask298", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask297", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask296", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask295", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask294", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask293", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask292", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask291", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask290", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask289", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask288", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask287", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask286", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask285", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask284", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask283", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:46 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask332\",\"eTag\":\"0x8D619B6F38B61C7\",\"lastModified\":\"2018-09-13T20:24:48.0244167Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask332\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask331\",\"eTag\":\"0x8D619B6F38C4E34\",\"lastModified\":\"2018-09-13T20:24:48.0304692Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask331\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask330\",\"eTag\":\"0x8D619B6F38DAE8E\",\"lastModified\":\"2018-09-13T20:24:48.0394894Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask330\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask329\",\"eTag\":\"0x8D619B6F38F5965\",\"lastModified\":\"2018-09-13T20:24:48.0504165Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask329\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask327\",\"eTag\":\"0x8D619B6F3959B07\",\"lastModified\":\"2018-09-13T20:24:48.0914183Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask327\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask328\",\"eTag\":\"0x8D619B6F39266B6\",\"lastModified\":\"2018-09-13T20:24:48.0704182Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask328\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask326\",\"eTag\":\"0x8D619B6F3981A38\",\"lastModified\":\"2018-09-13T20:24:48.1077816Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask326\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask324\",\"eTag\":\"0x8D619B6F39E26AB\",\"lastModified\":\"2018-09-13T20:24:48.1474219Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask324\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask323\",\"eTag\":\"0x8D619B6F39F5F20\",\"lastModified\":\"2018-09-13T20:24:48.1554208Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask323\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask325\",\"eTag\":\"0x8D619B6F39F86FE\",\"lastModified\":\"2018-09-13T20:24:48.1564414Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask325\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask322\",\"eTag\":\"0x8D619B6F3A133FA\",\"lastModified\":\"2018-09-13T20:24:48.1674234Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask322\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask321\",\"eTag\":\"0x8D619B6F3A1D044\",\"lastModified\":\"2018-09-13T20:24:48.1714244Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask321\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask320\",\"eTag\":\"0x8D619B6F3A57A39\",\"lastModified\":\"2018-09-13T20:24:48.1954361Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask320\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask319\",\"eTag\":\"0x8D619B6F3A5A0E2\",\"lastModified\":\"2018-09-13T20:24:48.1964258Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask319\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask318\",\"eTag\":\"0x8D619B6F3A6DA9E\",\"lastModified\":\"2018-09-13T20:24:48.2044574Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask318\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask316\",\"eTag\":\"0x8D619B6F3A84A9F\",\"lastModified\":\"2018-09-13T20:24:48.2138783Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask316\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask315\",\"eTag\":\"0x8D619B6F3A94C04\",\"lastModified\":\"2018-09-13T20:24:48.2204676Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask315\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask314\",\"eTag\":\"0x8D619B6F3AB6E94\",\"lastModified\":\"2018-09-13T20:24:48.2344596Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask314\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask317\",\"eTag\":\"0x8D619B6F3AB9481\",\"lastModified\":\"2018-09-13T20:24:48.2354305Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask317\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask312\",\"eTag\":\"0x8D619B6F3ACF3EA\",\"lastModified\":\"2018-09-13T20:24:48.2444266Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask312\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask313\",\"eTag\":\"0x8D619B6F3AD6921\",\"lastModified\":\"2018-09-13T20:24:48.2474273Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask313\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask311\",\"eTag\":\"0x8D619B6F3AE5BE2\",\"lastModified\":\"2018-09-13T20:24:48.2536418Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask311\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask310\",\"eTag\":\"0x8D619B6F3AE5BE2\",\"lastModified\":\"2018-09-13T20:24:48.2536418Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask310\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask309\",\"eTag\":\"0x8D619B6F3B0C482\",\"lastModified\":\"2018-09-13T20:24:48.2694274Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask309\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask308\",\"eTag\":\"0x8D619B6F3B13B43\",\"lastModified\":\"2018-09-13T20:24:48.2724675Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask308\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask307\",\"eTag\":\"0x8D619B6F3B2E750\",\"lastModified\":\"2018-09-13T20:24:48.2834256Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask307\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask306\",\"eTag\":\"0x8D619B6F3B2E750\",\"lastModified\":\"2018-09-13T20:24:48.2834256Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask306\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask305\",\"eTag\":\"0x8D619B6F3B46E07\",\"lastModified\":\"2018-09-13T20:24:48.2934279Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask305\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask304\",\"eTag\":\"0x8D619B6F3B5319E\",\"lastModified\":\"2018-09-13T20:24:48.298435Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask304\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask303\",\"eTag\":\"0x8D619B6F3B5F4B9\",\"lastModified\":\"2018-09-13T20:24:48.3034297Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask303\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask302\",\"eTag\":\"0x8D619B6F3B6B80D\",\"lastModified\":\"2018-09-13T20:24:48.3084301Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask302\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask301\",\"eTag\":\"0x8D619B6F3B76100\",\"lastModified\":\"2018-09-13T20:24:48.3127552Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask301\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask300\",\"eTag\":\"0x8D619B6F3B840CB\",\"lastModified\":\"2018-09-13T20:24:48.3184843Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask300\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask299\",\"eTag\":\"0x8D619B6F3BA5739\",\"lastModified\":\"2018-09-13T20:24:48.3321657Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask299\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask298\",\"eTag\":\"0x8D619B6F3BBD311\",\"lastModified\":\"2018-09-13T20:24:48.3418897Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask298\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask297\",\"eTag\":\"0x8D619B6F3BBE837\",\"lastModified\":\"2018-09-13T20:24:48.3424311Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask297\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask296\",\"eTag\":\"0x8D619B6F3BD2208\",\"lastModified\":\"2018-09-13T20:24:48.3504648Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask296\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask295\",\"eTag\":\"0x8D619B6F3BEA78F\",\"lastModified\":\"2018-09-13T20:24:48.3604367Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask295\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask294\",\"eTag\":\"0x8D619B6F3BFB8E1\",\"lastModified\":\"2018-09-13T20:24:48.3674337Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask294\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask293\",\"eTag\":\"0x8D619B6F3C11887\",\"lastModified\":\"2018-09-13T20:24:48.3764359Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask293\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask292\",\"eTag\":\"0x8D619B6F3C167BA\",\"lastModified\":\"2018-09-13T20:24:48.3784634Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask292\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask291\",\"eTag\":\"0x8D619B6F3C29F17\",\"lastModified\":\"2018-09-13T20:24:48.3864343Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask291\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask290\",\"eTag\":\"0x8D619B6F3C3D8B5\",\"lastModified\":\"2018-09-13T20:24:48.3944629Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask290\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask289\",\"eTag\":\"0x8D619B6F3C538E5\",\"lastModified\":\"2018-09-13T20:24:48.4034789Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask289\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask288\",\"eTag\":\"0x8D619B6F3C696C5\",\"lastModified\":\"2018-09-13T20:24:48.4124357Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask288\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask287\",\"eTag\":\"0x8D619B6F3C6E5FC\",\"lastModified\":\"2018-09-13T20:24:48.4144636Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask287\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask286\",\"eTag\":\"0x8D619B6F3C84466\",\"lastModified\":\"2018-09-13T20:24:48.4234342Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask286\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask285\",\"eTag\":\"0x8D619B6F3C985DA\",\"lastModified\":\"2018-09-13T20:24:48.4316634Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask285\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask284\",\"eTag\":\"0x8D619B6F3CAB57E\",\"lastModified\":\"2018-09-13T20:24:48.4394366Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask284\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask283\",\"eTag\":\"0x8D619B6F3CB2BC8\",\"lastModified\":\"2018-09-13T20:24:48.4424648Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask283\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:48 GMT'] + request-id: [45446534-d443-429c-aaa1-84895b80aa2e] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask282", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask281", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask280", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask279", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask278", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask277", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask276", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask275", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask274", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask273", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask272", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask271", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask270", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask269", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask268", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask267", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask266", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask265", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask264", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask263", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask262", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask261", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask260", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask259", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask258", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask257", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask256", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask255", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask254", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask253", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask252", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask251", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask250", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask249", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask248", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask247", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask246", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask245", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask244", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask243", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask242", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask241", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask240", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask239", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask238", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask237", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask236", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask235", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask234", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask233", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:48 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask282\",\"eTag\":\"0x8D619B6F4B266A6\",\"lastModified\":\"2018-09-13T20:24:49.9578534Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask282\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask279\",\"eTag\":\"0x8D619B6F4BA07B4\",\"lastModified\":\"2018-09-13T20:24:50.0078516Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask279\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask278\",\"eTag\":\"0x8D619B6F4BA2ECD\",\"lastModified\":\"2018-09-13T20:24:50.0088525Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask278\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask280\",\"eTag\":\"0x8D619B6F4BA07B4\",\"lastModified\":\"2018-09-13T20:24:50.0078516Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask280\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask281\",\"eTag\":\"0x8D619B6F4B9F23E\",\"lastModified\":\"2018-09-13T20:24:50.0073022Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask281\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask275\",\"eTag\":\"0x8D619B6F4BBDC70\",\"lastModified\":\"2018-09-13T20:24:50.0198512Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask275\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask274\",\"eTag\":\"0x8D619B6F4BEC2B4\",\"lastModified\":\"2018-09-13T20:24:50.0388532Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask274\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask273\",\"eTag\":\"0x8D619B6F4BEE9BB\",\"lastModified\":\"2018-09-13T20:24:50.0398523Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask273\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask277\",\"eTag\":\"0x8D619B6F4BE9B98\",\"lastModified\":\"2018-09-13T20:24:50.037852Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask277\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask272\",\"eTag\":\"0x8D619B6F4C181AD\",\"lastModified\":\"2018-09-13T20:24:50.0568493Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask272\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask271\",\"eTag\":\"0x8D619B6F4C1A8E7\",\"lastModified\":\"2018-09-13T20:24:50.0578535Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask271\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask276\",\"eTag\":\"0x8D619B6F4C1777C\",\"lastModified\":\"2018-09-13T20:24:50.0565884Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask276\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask270\",\"eTag\":\"0x8D619B6F4C37DA7\",\"lastModified\":\"2018-09-13T20:24:50.0698535Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask270\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask269\",\"eTag\":\"0x8D619B6F4C47ECB\",\"lastModified\":\"2018-09-13T20:24:50.0764363Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask269\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask268\",\"eTag\":\"0x8D619B6F4C50444\",\"lastModified\":\"2018-09-13T20:24:50.0798532Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask268\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask267\",\"eTag\":\"0x8D619B6F4C6159E\",\"lastModified\":\"2018-09-13T20:24:50.086851Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask267\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask266\",\"eTag\":\"0x8D619B6F4C6B1E8\",\"lastModified\":\"2018-09-13T20:24:50.090852Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask266\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask265\",\"eTag\":\"0x8D619B6F4C92302\",\"lastModified\":\"2018-09-13T20:24:50.1068546Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask265\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask262\",\"eTag\":\"0x8D619B6F4CC092D\",\"lastModified\":\"2018-09-13T20:24:50.1258541Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask262\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask264\",\"eTag\":\"0x8D619B6F4CA8303\",\"lastModified\":\"2018-09-13T20:24:50.1158659Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask264\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask263\",\"eTag\":\"0x8D619B6F4CB45D3\",\"lastModified\":\"2018-09-13T20:24:50.1208531Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask263\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask261\",\"eTag\":\"0x8D619B6F4CC7E6E\",\"lastModified\":\"2018-09-13T20:24:50.1288558Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask261\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask260\",\"eTag\":\"0x8D619B6F4CD8FC7\",\"lastModified\":\"2018-09-13T20:24:50.1358535Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask260\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask259\",\"eTag\":\"0x8D619B6F4D20324\",\"lastModified\":\"2018-09-13T20:24:50.1650212Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask259\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask256\",\"eTag\":\"0x8D619B6F4D223D4\",\"lastModified\":\"2018-09-13T20:24:50.165858Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask256\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask254\",\"eTag\":\"0x8D619B6F4D53103\",\"lastModified\":\"2018-09-13T20:24:50.1858563Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask254\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask255\",\"eTag\":\"0x8D619B6F4D298F4\",\"lastModified\":\"2018-09-13T20:24:50.1688564Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask255\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask258\",\"eTag\":\"0x8D619B6F4D271E5\",\"lastModified\":\"2018-09-13T20:24:50.1678565Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask258\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask253\",\"eTag\":\"0x8D619B6F4D67E4F\",\"lastModified\":\"2018-09-13T20:24:50.1943887Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask253\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask257\",\"eTag\":\"0x8D619B6F4D20324\",\"lastModified\":\"2018-09-13T20:24:50.1650212Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask257\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask251\",\"eTag\":\"0x8D619B6F4D88D21\",\"lastModified\":\"2018-09-13T20:24:50.2078753Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask251\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask252\",\"eTag\":\"0x8D619B6F4D6B7AF\",\"lastModified\":\"2018-09-13T20:24:50.1958575Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask252\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask249\",\"eTag\":\"0x8D619B6F4DB4BAF\",\"lastModified\":\"2018-09-13T20:24:50.2258607Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask249\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask250\",\"eTag\":\"0x8D619B6F4DB99C1\",\"lastModified\":\"2018-09-13T20:24:50.2278593Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask250\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask244\",\"eTag\":\"0x8D619B6F4E16641\",\"lastModified\":\"2018-09-13T20:24:50.2658625Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask244\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask242\",\"eTag\":\"0x8D619B6F4E732BA\",\"lastModified\":\"2018-09-13T20:24:50.303865Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask242\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask248\",\"eTag\":\"0x8D619B6F4DC8417\",\"lastModified\":\"2018-09-13T20:24:50.2338583Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask248\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask241\",\"eTag\":\"0x8D619B6F4E732BA\",\"lastModified\":\"2018-09-13T20:24:50.303865Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask241\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask246\",\"eTag\":\"0x8D619B6F4DE8007\",\"lastModified\":\"2018-09-13T20:24:50.2468615Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask246\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask247\",\"eTag\":\"0x8D619B6F4DF916B\",\"lastModified\":\"2018-09-13T20:24:50.2538603Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask247\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask245\",\"eTag\":\"0x8D619B6F4E13F30\",\"lastModified\":\"2018-09-13T20:24:50.2648624Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask245\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask238\",\"eTag\":\"0x8D619B6F4ED9B6D\",\"lastModified\":\"2018-09-13T20:24:50.3458669Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask238\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask239\",\"eTag\":\"0x8D619B6F4EA8E09\",\"lastModified\":\"2018-09-13T20:24:50.3258633Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask239\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask236\",\"eTag\":\"0x8D619B6F4F0A8CD\",\"lastModified\":\"2018-09-13T20:24:50.3658701Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask236\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask235\",\"eTag\":\"0x8D619B6F4F0A8CD\",\"lastModified\":\"2018-09-13T20:24:50.3658701Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask235\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask237\",\"eTag\":\"0x8D619B6F4EF21E7\",\"lastModified\":\"2018-09-13T20:24:50.3558631Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask237\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask240\",\"eTag\":\"0x8D619B6F4EB8A69\",\"lastModified\":\"2018-09-13T20:24:50.3323241Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask240\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask233\",\"eTag\":\"0x8D619B6F4F27D99\",\"lastModified\":\"2018-09-13T20:24:50.3778713Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask233\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask234\",\"eTag\":\"0x8D619B6F4F27D99\",\"lastModified\":\"2018-09-13T20:24:50.3778713Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask234\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask243\",\"eTag\":\"0x8D619B6F4E4736D\",\"lastModified\":\"2018-09-13T20:24:50.2858605Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask243\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:49 GMT'] + request-id: [4717365c-9442-4719-a158-b4eec97bd3f6] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask232", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask231", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask230", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask229", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask228", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask227", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask226", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask225", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask224", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask223", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask222", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask221", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask220", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask219", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask218", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask217", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask216", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask215", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask214", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask213", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask212", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask211", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask210", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask209", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask208", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask207", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask206", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask205", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask204", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask203", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask202", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask201", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask200", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask199", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask198", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask197", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask196", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask195", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask194", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask193", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask192", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask191", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask190", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask189", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask188", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask187", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask186", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask185", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask184", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask183", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:50 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask232\",\"eTag\":\"0x8D619B6F5D6E479\",\"lastModified\":\"2018-09-13T20:24:51.8747257Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask232\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask231\",\"eTag\":\"0x8D619B6F5D86B34\",\"lastModified\":\"2018-09-13T20:24:51.8847284Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask231\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask230\",\"eTag\":\"0x8D619B6F5D9F1BE\",\"lastModified\":\"2018-09-13T20:24:51.8947262Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask230\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask229\",\"eTag\":\"0x8D619B6F5DB795F\",\"lastModified\":\"2018-09-13T20:24:51.9047519Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask229\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask228\",\"eTag\":\"0x8D619B6F5DD0388\",\"lastModified\":\"2018-09-13T20:24:51.9148424Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask228\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask227\",\"eTag\":\"0x8D619B6F5DE8579\",\"lastModified\":\"2018-09-13T20:24:51.9247225Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask227\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask226\",\"eTag\":\"0x8D619B6F5E178ED\",\"lastModified\":\"2018-09-13T20:24:51.9440621Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask226\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask225\",\"eTag\":\"0x8D619B6F5E2F45A\",\"lastModified\":\"2018-09-13T20:24:51.9537754Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask225\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask224\",\"eTag\":\"0x8D619B6F5E47A9A\",\"lastModified\":\"2018-09-13T20:24:51.9637658Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask224\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask223\",\"eTag\":\"0x8D619B6F5E6008B\",\"lastModified\":\"2018-09-13T20:24:51.9737483Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask223\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask222\",\"eTag\":\"0x8D619B6F5E787FF\",\"lastModified\":\"2018-09-13T20:24:51.9837695Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask222\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask219\",\"eTag\":\"0x8D619B6F5EF758F\",\"lastModified\":\"2018-09-13T20:24:52.0357263Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask219\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask217\",\"eTag\":\"0x8D619B6F5F0FC20\",\"lastModified\":\"2018-09-13T20:24:52.0457248Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask217\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask221\",\"eTag\":\"0x8D619B6F5E90CDF\",\"lastModified\":\"2018-09-13T20:24:51.9937247Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask221\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask220\",\"eTag\":\"0x8D619B6F5EFC3BB\",\"lastModified\":\"2018-09-13T20:24:52.0377275Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask220\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask218\",\"eTag\":\"0x8D619B6F5F2D0FB\",\"lastModified\":\"2018-09-13T20:24:52.0577275Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask218\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask216\",\"eTag\":\"0x8D619B6F5F457AA\",\"lastModified\":\"2018-09-13T20:24:52.067729Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask216\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask210\",\"eTag\":\"0x8D619B6F5FA2418\",\"lastModified\":\"2018-09-13T20:24:52.1057304Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask210\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask215\",\"eTag\":\"0x8D619B6F5F59018\",\"lastModified\":\"2018-09-13T20:24:52.0757272Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask215\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask209\",\"eTag\":\"0x8D619B6F5FBFDD3\",\"lastModified\":\"2018-09-13T20:24:52.1178579Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask209\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask207\",\"eTag\":\"0x8D619B6F5FE7CB6\",\"lastModified\":\"2018-09-13T20:24:52.1342134Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask207\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask208\",\"eTag\":\"0x8D619B6F5FD586B\",\"lastModified\":\"2018-09-13T20:24:52.1267307Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask208\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask213\",\"eTag\":\"0x8D619B6F5F89D6B\",\"lastModified\":\"2018-09-13T20:24:52.0957291Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask213\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask214\",\"eTag\":\"0x8D619B6F5F764F5\",\"lastModified\":\"2018-09-13T20:24:52.0877301Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask214\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask211\",\"eTag\":\"0x8D619B6F601C55D\",\"lastModified\":\"2018-09-13T20:24:52.1557341Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask211\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask206\",\"eTag\":\"0x8D619B6F6003EA5\",\"lastModified\":\"2018-09-13T20:24:52.1457317Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask206\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask205\",\"eTag\":\"0x8D619B6F6019E39\",\"lastModified\":\"2018-09-13T20:24:52.1547321Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask205\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask204\",\"eTag\":\"0x8D619B6F6019E39\",\"lastModified\":\"2018-09-13T20:24:52.1547321Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask204\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask203\",\"eTag\":\"0x8D619B6F602FDC7\",\"lastModified\":\"2018-09-13T20:24:52.1637319Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask203\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask212\",\"eTag\":\"0x8D619B6F5F8C489\",\"lastModified\":\"2018-09-13T20:24:52.0967305Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask212\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask202\",\"eTag\":\"0x8D619B6F60C25B2\",\"lastModified\":\"2018-09-13T20:24:52.2237362Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask202\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask199\",\"eTag\":\"0x8D619B6F60F5A05\",\"lastModified\":\"2018-09-13T20:24:52.2447365Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask199\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask195\",\"eTag\":\"0x8D619B6F61107B6\",\"lastModified\":\"2018-09-13T20:24:52.2557366Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask195\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask193\",\"eTag\":\"0x8D619B6F61351A7\",\"lastModified\":\"2018-09-13T20:24:52.2707367Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask193\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask194\",\"eTag\":\"0x8D619B6F61378CA\",\"lastModified\":\"2018-09-13T20:24:52.2717386Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask194\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask192\",\"eTag\":\"0x8D619B6F6139FE1\",\"lastModified\":\"2018-09-13T20:24:52.2727393Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask192\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask190\",\"eTag\":\"0x8D619B6F617704D\",\"lastModified\":\"2018-09-13T20:24:52.2977357Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask190\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask201\",\"eTag\":\"0x8D619B6F60D74FE\",\"lastModified\":\"2018-09-13T20:24:52.2323198Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask201\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask198\",\"eTag\":\"0x8D619B6F618F71C\",\"lastModified\":\"2018-09-13T20:24:52.3077404Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask198\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask189\",\"eTag\":\"0x8D619B6F617E5A0\",\"lastModified\":\"2018-09-13T20:24:52.3007392Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask189\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask188\",\"eTag\":\"0x8D619B6F618D1AF\",\"lastModified\":\"2018-09-13T20:24:52.3067823Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask188\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask200\",\"eTag\":\"0x8D619B6F60C73D2\",\"lastModified\":\"2018-09-13T20:24:52.2257362Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask200\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask187\",\"eTag\":\"0x8D619B6F6191E29\",\"lastModified\":\"2018-09-13T20:24:52.3087401Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask187\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask197\",\"eTag\":\"0x8D619B6F6194542\",\"lastModified\":\"2018-09-13T20:24:52.309741Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask197\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask186\",\"eTag\":\"0x8D619B6F61CA19F\",\"lastModified\":\"2018-09-13T20:24:52.3317663Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask186\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask196\",\"eTag\":\"0x8D619B6F6191E29\",\"lastModified\":\"2018-09-13T20:24:52.3087401Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask196\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask185\",\"eTag\":\"0x8D619B6F61E2895\",\"lastModified\":\"2018-09-13T20:24:52.3417749Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask185\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask191\",\"eTag\":\"0x8D619B6F61E9C73\",\"lastModified\":\"2018-09-13T20:24:52.3447411Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask191\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask184\",\"eTag\":\"0x8D619B6F61E9C73\",\"lastModified\":\"2018-09-13T20:24:52.3447411Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask184\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask183\",\"eTag\":\"0x8D619B6F61E9C73\",\"lastModified\":\"2018-09-13T20:24:52.3447411Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask183\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:51 GMT'] + request-id: [72d27b7d-7e5b-4cb9-a4a6-bbbeff8c1b3b] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask182", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask181", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask180", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask179", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask178", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask177", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask176", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask175", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask174", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask173", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask172", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask171", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask170", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask169", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask168", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask167", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask166", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask165", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask164", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask163", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask162", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask161", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask160", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask159", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask158", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask157", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask156", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask155", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask154", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask153", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask152", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask151", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask150", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask149", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask148", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask147", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask146", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask145", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask144", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask143", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask142", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask141", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask140", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask139", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask138", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask137", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask136", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask135", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask134", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask133", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587311'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:52 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask182\",\"eTag\":\"0x8D619B6F707E733\",\"lastModified\":\"2018-09-13T20:24:53.8736435Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask182\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask181\",\"eTag\":\"0x8D619B6F70A0B34\",\"lastModified\":\"2018-09-13T20:24:53.8876724Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask181\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask179\",\"eTag\":\"0x8D619B6F70DDC07\",\"lastModified\":\"2018-09-13T20:24:53.9126791Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask179\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask180\",\"eTag\":\"0x8D619B6F70CF176\",\"lastModified\":\"2018-09-13T20:24:53.9066742Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask180\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask177\",\"eTag\":\"0x8D619B6F70E01EF\",\"lastModified\":\"2018-09-13T20:24:53.9136495Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask177\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask175\",\"eTag\":\"0x8D619B6F70FFDC6\",\"lastModified\":\"2018-09-13T20:24:53.9266502Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask175\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask174\",\"eTag\":\"0x8D619B6F711845C\",\"lastModified\":\"2018-09-13T20:24:53.9366492Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask174\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask169\",\"eTag\":\"0x8D619B6F718FE8B\",\"lastModified\":\"2018-09-13T20:24:53.9856523Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask169\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask168\",\"eTag\":\"0x8D619B6F71A8532\",\"lastModified\":\"2018-09-13T20:24:53.995653Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask168\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask176\",\"eTag\":\"0x8D619B6F70F3A57\",\"lastModified\":\"2018-09-13T20:24:53.9216471Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask176\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask173\",\"eTag\":\"0x8D619B6F712E3ED\",\"lastModified\":\"2018-09-13T20:24:53.9456493Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask173\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask167\",\"eTag\":\"0x8D619B6F71AAC47\",\"lastModified\":\"2018-09-13T20:24:53.9966535Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask167\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask172\",\"eTag\":\"0x8D619B6F714B8BC\",\"lastModified\":\"2018-09-13T20:24:53.9576508Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask172\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask171\",\"eTag\":\"0x8D619B6F7175971\",\"lastModified\":\"2018-09-13T20:24:53.9748721Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask171\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask178\",\"eTag\":\"0x8D619B6F70E01EF\",\"lastModified\":\"2018-09-13T20:24:53.9136495Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask178\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask170\",\"eTag\":\"0x8D619B6F717C606\",\"lastModified\":\"2018-09-13T20:24:53.9776518Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask170\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask166\",\"eTag\":\"0x8D619B6F71D6B6F\",\"lastModified\":\"2018-09-13T20:24:54.0146543Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask166\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask164\",\"eTag\":\"0x8D619B6F71EF210\",\"lastModified\":\"2018-09-13T20:24:54.0246544Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask164\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask165\",\"eTag\":\"0x8D619B6F71F1920\",\"lastModified\":\"2018-09-13T20:24:54.0256544Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask165\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask163\",\"eTag\":\"0x8D619B6F71F4039\",\"lastModified\":\"2018-09-13T20:24:54.0266553Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask163\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask151\",\"eTag\":\"0x8D619B6F7386DCF\",\"lastModified\":\"2018-09-13T20:24:54.1916623Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask151\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask149\",\"eTag\":\"0x8D619B6F73846B8\",\"lastModified\":\"2018-09-13T20:24:54.1906616Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask149\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask150\",\"eTag\":\"0x8D619B6F73846B8\",\"lastModified\":\"2018-09-13T20:24:54.1906616Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask150\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask161\",\"eTag\":\"0x8D619B6F7250C90\",\"lastModified\":\"2018-09-13T20:24:54.0646544Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask161\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask162\",\"eTag\":\"0x8D619B6F723D415\",\"lastModified\":\"2018-09-13T20:24:54.0566549Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask162\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask148\",\"eTag\":\"0x8D619B6F73B31A4\",\"lastModified\":\"2018-09-13T20:24:54.2097828Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask148\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask160\",\"eTag\":\"0x8D619B6F72533B7\",\"lastModified\":\"2018-09-13T20:24:54.0656567Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask160\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask147\",\"eTag\":\"0x8D619B6F73B5492\",\"lastModified\":\"2018-09-13T20:24:54.210677Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask147\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask159\",\"eTag\":\"0x8D619B6F729A094\",\"lastModified\":\"2018-09-13T20:24:54.094658Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask159\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask158\",\"eTag\":\"0x8D619B6F72B2737\",\"lastModified\":\"2018-09-13T20:24:54.1046583Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask158\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask156\",\"eTag\":\"0x8D619B6F72B4E3C\",\"lastModified\":\"2018-09-13T20:24:54.1056572Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask156\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask157\",\"eTag\":\"0x8D619B6F72C3E80\",\"lastModified\":\"2018-09-13T20:24:54.111808Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask157\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask143\",\"eTag\":\"0x8D619B6F745B467\",\"lastModified\":\"2018-09-13T20:24:54.2786663Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask143\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask152\",\"eTag\":\"0x8D619B6F7473B01\",\"lastModified\":\"2018-09-13T20:24:54.2886657Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask152\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask140\",\"eTag\":\"0x8D619B6F7473B01\",\"lastModified\":\"2018-09-13T20:24:54.2886657Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask140\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask155\",\"eTag\":\"0x8D619B6F72DBF56\",\"lastModified\":\"2018-09-13T20:24:54.1216598Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask155\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask142\",\"eTag\":\"0x8D619B6F745DB72\",\"lastModified\":\"2018-09-13T20:24:54.2796658Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask142\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask153\",\"eTag\":\"0x8D619B6F72F6CFA\",\"lastModified\":\"2018-09-13T20:24:54.1326586Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask153\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask139\",\"eTag\":\"0x8D619B6F7460288\",\"lastModified\":\"2018-09-13T20:24:54.2806664Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask139\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask141\",\"eTag\":\"0x8D619B6F745DB72\",\"lastModified\":\"2018-09-13T20:24:54.2796658Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask141\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask154\",\"eTag\":\"0x8D619B6F7460288\",\"lastModified\":\"2018-09-13T20:24:54.2806664Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask154\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask145\",\"eTag\":\"0x8D619B6F75FCD9E\",\"lastModified\":\"2018-09-13T20:24:54.4497054Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask145\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask144\",\"eTag\":\"0x8D619B6F75FFFDB\",\"lastModified\":\"2018-09-13T20:24:54.4509915Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask144\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask137\",\"eTag\":\"0x8D619B6F75FCD9E\",\"lastModified\":\"2018-09-13T20:24:54.4497054Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask137\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask135\",\"eTag\":\"0x8D619B6F7606887\",\"lastModified\":\"2018-09-13T20:24:54.4536711Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask135\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask138\",\"eTag\":\"0x8D619B6F7606887\",\"lastModified\":\"2018-09-13T20:24:54.4536711Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask138\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask146\",\"eTag\":\"0x8D619B6F75FCD9E\",\"lastModified\":\"2018-09-13T20:24:54.4497054Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask146\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask134\",\"eTag\":\"0x8D619B6F7606887\",\"lastModified\":\"2018-09-13T20:24:54.4536711Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask134\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask136\",\"eTag\":\"0x8D619B6F7606887\",\"lastModified\":\"2018-09-13T20:24:54.4536711Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask136\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask133\",\"eTag\":\"0x8D619B6F7606887\",\"lastModified\":\"2018-09-13T20:24:54.4536711Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask133\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:54 GMT'] + request-id: [bd6a39fc-a9b7-4c0d-bca0-0a7d0ac200d2] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask132", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask131", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask130", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask129", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask128", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask127", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask126", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask125", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask124", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask123", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask122", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask121", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask120", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask119", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask118", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask117", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask116", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask115", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask114", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask113", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask112", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask111", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask110", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask109", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask108", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask107", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask106", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask105", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask104", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask103", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask102", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask101", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask100", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask99", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask98", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask97", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask96", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask95", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask94", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask93", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask92", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask91", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask90", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask89", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask88", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask87", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask86", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask85", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask84", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask83", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587294'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:54 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask132\",\"eTag\":\"0x8D619B6F84C66B2\",\"lastModified\":\"2018-09-13T20:24:56.0002738Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask132\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask131\",\"eTag\":\"0x8D619B6F8501180\",\"lastModified\":\"2018-09-13T20:24:56.0243072Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask131\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask130\",\"eTag\":\"0x8D619B6F85170F9\",\"lastModified\":\"2018-09-13T20:24:56.0333049Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask130\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask129\",\"eTag\":\"0x8D619B6F8525B71\",\"lastModified\":\"2018-09-13T20:24:56.0393073Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask129\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask128\",\"eTag\":\"0x8D619B6F8545D11\",\"lastModified\":\"2018-09-13T20:24:56.0524561Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask128\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask127\",\"eTag\":\"0x8D619B6F855DE1D\",\"lastModified\":\"2018-09-13T20:24:56.0623133Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask127\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask126\",\"eTag\":\"0x8D619B6F857B16E\",\"lastModified\":\"2018-09-13T20:24:56.0742766Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask126\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask124\",\"eTag\":\"0x8D619B6F85C4556\",\"lastModified\":\"2018-09-13T20:24:56.1042774Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask124\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask125\",\"eTag\":\"0x8D619B6F85C93B6\",\"lastModified\":\"2018-09-13T20:24:56.1062838Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask125\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask121\",\"eTag\":\"0x8D619B6F85F2B6F\",\"lastModified\":\"2018-09-13T20:24:56.1232751Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask121\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask123\",\"eTag\":\"0x8D619B6F86211B4\",\"lastModified\":\"2018-09-13T20:24:56.1422772Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask123\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask122\",\"eTag\":\"0x8D619B6F85F529A\",\"lastModified\":\"2018-09-13T20:24:56.1242778Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask122\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask120\",\"eTag\":\"0x8D619B6F86286FB\",\"lastModified\":\"2018-09-13T20:24:56.1452795Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask120\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask119\",\"eTag\":\"0x8D619B6F8638969\",\"lastModified\":\"2018-09-13T20:24:56.1518953Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask119\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask118\",\"eTag\":\"0x8D619B6F864ABC4\",\"lastModified\":\"2018-09-13T20:24:56.1593284Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask118\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask116\",\"eTag\":\"0x8D619B6F866F547\",\"lastModified\":\"2018-09-13T20:24:56.1743175Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask116\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask115\",\"eTag\":\"0x8D619B6F86916C0\",\"lastModified\":\"2018-09-13T20:24:56.1882816Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask115\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask112\",\"eTag\":\"0x8D619B6F86B87A6\",\"lastModified\":\"2018-09-13T20:24:56.204279Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask112\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask114\",\"eTag\":\"0x8D619B6F86A4F30\",\"lastModified\":\"2018-09-13T20:24:56.19628Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask114\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask117\",\"eTag\":\"0x8D619B6F86B87A6\",\"lastModified\":\"2018-09-13T20:24:56.204279Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask117\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask113\",\"eTag\":\"0x8D619B6F86BAED6\",\"lastModified\":\"2018-09-13T20:24:56.2052822Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask113\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask110\",\"eTag\":\"0x8D619B6F86BD5D8\",\"lastModified\":\"2018-09-13T20:24:56.2062808Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask110\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask107\",\"eTag\":\"0x8D619B6F873772D\",\"lastModified\":\"2018-09-13T20:24:56.2562861Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask107\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask105\",\"eTag\":\"0x8D619B6F874D6B3\",\"lastModified\":\"2018-09-13T20:24:56.2652851Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask105\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask104\",\"eTag\":\"0x8D619B6F8765D36\",\"lastModified\":\"2018-09-13T20:24:56.2752822Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask104\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask106\",\"eTag\":\"0x8D619B6F87795E0\",\"lastModified\":\"2018-09-13T20:24:56.2832864Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask106\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask102\",\"eTag\":\"0x8D619B6F877BCC9\",\"lastModified\":\"2018-09-13T20:24:56.2842825Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask102\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask109\",\"eTag\":\"0x8D619B6F8714EA9\",\"lastModified\":\"2018-09-13T20:24:56.2421417Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask109\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask108\",\"eTag\":\"0x8D619B6F871542D\",\"lastModified\":\"2018-09-13T20:24:56.2422829Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask108\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask101\",\"eTag\":\"0x8D619B6F87D66AA\",\"lastModified\":\"2018-09-13T20:24:56.3213994Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask101\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask103\",\"eTag\":\"0x8D619B6F87DB071\",\"lastModified\":\"2018-09-13T20:24:56.3232881Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask103\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask111\",\"eTag\":\"0x8D619B6F87042BA\",\"lastModified\":\"2018-09-13T20:24:56.2352826Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask111\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask99\",\"eTag\":\"0x8D619B6F8826B62\",\"lastModified\":\"2018-09-13T20:24:56.3542882Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask99\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask100\",\"eTag\":\"0x8D619B6F884F11F\",\"lastModified\":\"2018-09-13T20:24:56.3708191Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask100\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask96\",\"eTag\":\"0x8D619B6F88674BF\",\"lastModified\":\"2018-09-13T20:24:56.3807423Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask96\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask97\",\"eTag\":\"0x8D619B6F8868A2F\",\"lastModified\":\"2018-09-13T20:24:56.3812911Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask97\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask92\",\"eTag\":\"0x8D619B6F88A5ABC\",\"lastModified\":\"2018-09-13T20:24:56.4062908Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask92\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask88\",\"eTag\":\"0x8D619B6F88DF76C\",\"lastModified\":\"2018-09-13T20:24:56.4299628Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask88\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask89\",\"eTag\":\"0x8D619B6F88CA4B9\",\"lastModified\":\"2018-09-13T20:24:56.4212921Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask89\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask90\",\"eTag\":\"0x8D619B6F88CA4B9\",\"lastModified\":\"2018-09-13T20:24:56.4212921Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask90\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask95\",\"eTag\":\"0x8D619B6F8915FB7\",\"lastModified\":\"2018-09-13T20:24:56.4522935Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask95\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask83\",\"eTag\":\"0x8D619B6F8915FB7\",\"lastModified\":\"2018-09-13T20:24:56.4522935Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask83\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask85\",\"eTag\":\"0x8D619B6F8911194\",\"lastModified\":\"2018-09-13T20:24:56.4502932Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask85\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask98\",\"eTag\":\"0x8D619B6F8915FB7\",\"lastModified\":\"2018-09-13T20:24:56.4522935Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask98\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask84\",\"eTag\":\"0x8D619B6F8915FB7\",\"lastModified\":\"2018-09-13T20:24:56.4522935Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask84\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask94\",\"eTag\":\"0x8D619B6F8915FB7\",\"lastModified\":\"2018-09-13T20:24:56.4522935Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask94\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask86\",\"eTag\":\"0x8D619B6F890EF1C\",\"lastModified\":\"2018-09-13T20:24:56.4494108Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask86\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask91\",\"eTag\":\"0x8D619B6F893E18E\",\"lastModified\":\"2018-09-13T20:24:56.4687246Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask91\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask93\",\"eTag\":\"0x8D619B6F893F7CA\",\"lastModified\":\"2018-09-13T20:24:56.4692938Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask93\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask87\",\"eTag\":\"0x8D619B6F893F7CA\",\"lastModified\":\"2018-09-13T20:24:56.4692938Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask87\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:55 GMT'] + request-id: [3a34978b-6070-4b84-b4d1-9d053a6173f4] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask82", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask81", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask80", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask79", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask78", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask77", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask76", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask75", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask74", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask73", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask72", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask71", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask70", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask69", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask68", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask67", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask66", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask65", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask64", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask63", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask62", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask61", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask60", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask59", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask58", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask57", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask56", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask55", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask54", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask53", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask52", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask51", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask50", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask49", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask48", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask47", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask46", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask45", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask44", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask43", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask42", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask41", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask40", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask39", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask38", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask37", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask36", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask35", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask34", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask33", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587261'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:56 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask82\",\"eTag\":\"0x8D619B6F97A3FEC\",\"lastModified\":\"2018-09-13T20:24:57.9784684Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask82\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask81\",\"eTag\":\"0x8D619B6F97B74A1\",\"lastModified\":\"2018-09-13T20:24:57.9863713Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask81\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask80\",\"eTag\":\"0x8D619B6F97CF31A\",\"lastModified\":\"2018-09-13T20:24:57.9961626Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask80\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask79\",\"eTag\":\"0x8D619B6F97EADA8\",\"lastModified\":\"2018-09-13T20:24:58.007492Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask79\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask77\",\"eTag\":\"0x8D619B6F98367CB\",\"lastModified\":\"2018-09-13T20:24:58.0384715Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask77\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask75\",\"eTag\":\"0x8D619B6F9862062\",\"lastModified\":\"2018-09-13T20:24:58.0563042Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask75\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask78\",\"eTag\":\"0x8D619B6F98626D0\",\"lastModified\":\"2018-09-13T20:24:58.0564688Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask78\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask74\",\"eTag\":\"0x8D619B6F9895B47\",\"lastModified\":\"2018-09-13T20:24:58.0774727Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask74\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask72\",\"eTag\":\"0x8D619B6F989279E\",\"lastModified\":\"2018-09-13T20:24:58.0761502Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask72\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask71\",\"eTag\":\"0x8D619B6F9898253\",\"lastModified\":\"2018-09-13T20:24:58.0784723Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask71\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask73\",\"eTag\":\"0x8D619B6F987A3F4\",\"lastModified\":\"2018-09-13T20:24:58.066226Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask73\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask76\",\"eTag\":\"0x8D619B6F98C272C\",\"lastModified\":\"2018-09-13T20:24:58.0957996Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask76\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask70\",\"eTag\":\"0x8D619B6F98C3191\",\"lastModified\":\"2018-09-13T20:24:58.0960657Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask70\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask69\",\"eTag\":\"0x8D619B6F98D2BFA\",\"lastModified\":\"2018-09-13T20:24:58.1024762Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask69\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask68\",\"eTag\":\"0x8D619B6F98F1B04\",\"lastModified\":\"2018-09-13T20:24:58.1151492Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask68\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask67\",\"eTag\":\"0x8D619B6F98F4EC5\",\"lastModified\":\"2018-09-13T20:24:58.1164741Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask67\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask66\",\"eTag\":\"0x8D619B6F99061D3\",\"lastModified\":\"2018-09-13T20:24:58.1235155Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask66\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask65\",\"eTag\":\"0x8D619B6F99172BE\",\"lastModified\":\"2018-09-13T20:24:58.1305022Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask65\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask64\",\"eTag\":\"0x8D619B6F991E722\",\"lastModified\":\"2018-09-13T20:24:58.1334818Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask64\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask63\",\"eTag\":\"0x8D619B6F993480B\",\"lastModified\":\"2018-09-13T20:24:58.1425163Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask63\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask62\",\"eTag\":\"0x8D619B6F994A718\",\"lastModified\":\"2018-09-13T20:24:58.1515032Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask62\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask61\",\"eTag\":\"0x8D619B6F994CD37\",\"lastModified\":\"2018-09-13T20:24:58.1524791Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask61\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask60\",\"eTag\":\"0x8D619B6F99655E3\",\"lastModified\":\"2018-09-13T20:24:58.1625315Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask60\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask59\",\"eTag\":\"0x8D619B6F9976548\",\"lastModified\":\"2018-09-13T20:24:58.1694792Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask59\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask57\",\"eTag\":\"0x8D619B6F9996316\",\"lastModified\":\"2018-09-13T20:24:58.1825302Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask57\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask55\",\"eTag\":\"0x8D619B6F99B36B4\",\"lastModified\":\"2018-09-13T20:24:58.1945012Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask55\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask56\",\"eTag\":\"0x8D619B6F99A9B70\",\"lastModified\":\"2018-09-13T20:24:58.1905264Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask56\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask58\",\"eTag\":\"0x8D619B6F99BAB0F\",\"lastModified\":\"2018-09-13T20:24:58.1974799Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask58\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask54\",\"eTag\":\"0x8D619B6F99C7050\",\"lastModified\":\"2018-09-13T20:24:58.2025296Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask54\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask52\",\"eTag\":\"0x8D619B6F99DF51C\",\"lastModified\":\"2018-09-13T20:24:58.2124828Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask52\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask53\",\"eTag\":\"0x8D619B6F99E6DE4\",\"lastModified\":\"2018-09-13T20:24:58.2155748Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask53\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask51\",\"eTag\":\"0x8D619B6F99F7D45\",\"lastModified\":\"2018-09-13T20:24:58.2225221Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask51\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask49\",\"eTag\":\"0x8D619B6F9A0E188\",\"lastModified\":\"2018-09-13T20:24:58.2316424Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask49\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask50\",\"eTag\":\"0x8D619B6F9A0B538\",\"lastModified\":\"2018-09-13T20:24:58.230508Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask50\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask48\",\"eTag\":\"0x8D619B6F9A2FF0A\",\"lastModified\":\"2018-09-13T20:24:58.245505Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask48\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask47\",\"eTag\":\"0x8D619B6F9A3C24F\",\"lastModified\":\"2018-09-13T20:24:58.2505039Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask47\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask46\",\"eTag\":\"0x8D619B6F9A520D7\",\"lastModified\":\"2018-09-13T20:24:58.2594775Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask46\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask44\",\"eTag\":\"0x8D619B6F9A5E444\",\"lastModified\":\"2018-09-13T20:24:58.2644804Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask44\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask45\",\"eTag\":\"0x8D619B6F9A5DD40\",\"lastModified\":\"2018-09-13T20:24:58.2643008Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask45\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask43\",\"eTag\":\"0x8D619B6F9A75EB0\",\"lastModified\":\"2018-09-13T20:24:58.274168Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask43\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask42\",\"eTag\":\"0x8D619B6F9A8566E\",\"lastModified\":\"2018-09-13T20:24:58.2805102Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask42\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask41\",\"eTag\":\"0x8D619B6F9A98EF8\",\"lastModified\":\"2018-09-13T20:24:58.2885112Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask41\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask40\",\"eTag\":\"0x8D619B6F9AA04D0\",\"lastModified\":\"2018-09-13T20:24:58.291528Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask40\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask39\",\"eTag\":\"0x8D619B6F9AC25C6\",\"lastModified\":\"2018-09-13T20:24:58.305479Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask39\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask37\",\"eTag\":\"0x8D619B6F9AD5E87\",\"lastModified\":\"2018-09-13T20:24:58.3134855Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask37\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask38\",\"eTag\":\"0x8D619B6F9AD1234\",\"lastModified\":\"2018-09-13T20:24:58.3115316Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask38\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask36\",\"eTag\":\"0x8D619B6F9AF2C6E\",\"lastModified\":\"2018-09-13T20:24:58.3253102Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask36\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask35\",\"eTag\":\"0x8D619B6F9B01F88\",\"lastModified\":\"2018-09-13T20:24:58.3315336Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask35\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask34\",\"eTag\":\"0x8D619B6F9B1A50C\",\"lastModified\":\"2018-09-13T20:24:58.3415052Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask34\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask33\",\"eTag\":\"0x8D619B6F9B29047\",\"lastModified\":\"2018-09-13T20:24:58.3475271Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask33\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:57 GMT'] + request-id: [8e168d54-1655-45c1-a126-aff72187d9e9] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask32", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask31", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask30", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask29", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask28", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask27", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask26", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask25", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask24", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask23", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask22", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask21", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask20", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask19", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask18", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask17", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask16", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask15", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask14", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask13", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask12", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask11", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask10", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask9", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask8", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask7", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask6", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask5", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask4", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask3", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask2", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask1", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask0", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask682", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask681", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask680", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask679", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask678", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask677", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask676", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask675", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask674", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask673", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask672", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask671", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask670", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask669", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask668", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask667", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask666", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['587268'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:24:58 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask32\",\"eTag\":\"0x8D619B6FA950C38\",\"lastModified\":\"2018-09-13T20:24:59.8318136Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask32\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask31\",\"eTag\":\"0x8D619B6FA96226A\",\"lastModified\":\"2018-09-13T20:24:59.8389354Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask31\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask29\",\"eTag\":\"0x8D619B6FA98DCC7\",\"lastModified\":\"2018-09-13T20:24:59.8568135Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask29\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask28\",\"eTag\":\"0x8D619B6FA99DDA2\",\"lastModified\":\"2018-09-13T20:24:59.863389Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask28\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask30\",\"eTag\":\"0x8D619B6FA977EFF\",\"lastModified\":\"2018-09-13T20:24:59.8478591Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask30\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask27\",\"eTag\":\"0x8D619B6FA9BC465\",\"lastModified\":\"2018-09-13T20:24:59.8758501Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask27\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask26\",\"eTag\":\"0x8D619B6FA9CFBD7\",\"lastModified\":\"2018-09-13T20:24:59.8838231Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask26\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask25\",\"eTag\":\"0x8D619B6FAA085B1\",\"lastModified\":\"2018-09-13T20:24:59.9070129Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask25\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask24\",\"eTag\":\"0x8D619B6FAA18FCF\",\"lastModified\":\"2018-09-13T20:24:59.9138255Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask24\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask23\",\"eTag\":\"0x8D619B6FAA37D50\",\"lastModified\":\"2018-09-13T20:24:59.9264592Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask23\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask22\",\"eTag\":\"0x8D619B6FAA538EE\",\"lastModified\":\"2018-09-13T20:24:59.9378158Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask22\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask21\",\"eTag\":\"0x8D619B6FAA5FC41\",\"lastModified\":\"2018-09-13T20:24:59.9428161Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask21\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask20\",\"eTag\":\"0x8D619B6FAA7F0E0\",\"lastModified\":\"2018-09-13T20:24:59.955632Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask20\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask19\",\"eTag\":\"0x8D619B6FAA89454\",\"lastModified\":\"2018-09-13T20:24:59.9598164Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask19\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask18\",\"eTag\":\"0x8D619B6FAAE128B\",\"lastModified\":\"2018-09-13T20:24:59.9958155Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask18\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask17\",\"eTag\":\"0x8D619B6FAB0F8CE\",\"lastModified\":\"2018-09-13T20:25:00.0148174Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask17\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask16\",\"eTag\":\"0x8D619B6FAB2583F\",\"lastModified\":\"2018-09-13T20:25:00.0238143Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask16\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask9\",\"eTag\":\"0x8D619B6FAB56585\",\"lastModified\":\"2018-09-13T20:25:00.0438149Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask9\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask15\",\"eTag\":\"0x8D619B6FABB0B72\",\"lastModified\":\"2018-09-13T20:25:00.0808306Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask15\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask13\",\"eTag\":\"0x8D619B6FAB27F65\",\"lastModified\":\"2018-09-13T20:25:00.0248165Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask13\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask11\",\"eTag\":\"0x8D619B6FAB56585\",\"lastModified\":\"2018-09-13T20:25:00.0438149Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask11\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask10\",\"eTag\":\"0x8D619B6FAB56585\",\"lastModified\":\"2018-09-13T20:25:00.0438149Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask10\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask14\",\"eTag\":\"0x8D619B6FABB0B72\",\"lastModified\":\"2018-09-13T20:25:00.0808306Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask14\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask0\",\"eTag\":\"0x8D619B6FACE9300\",\"lastModified\":\"2018-09-13T20:25:00.2088192Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask0\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask8\",\"eTag\":\"0x8D619B6FACE9300\",\"lastModified\":\"2018-09-13T20:25:00.2088192Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask8\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask2\",\"eTag\":\"0x8D619B6FACDC17B\",\"lastModified\":\"2018-09-13T20:25:00.2034555Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask2\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask681\",\"eTag\":\"0x8D619B6FACE9300\",\"lastModified\":\"2018-09-13T20:25:00.2088192Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask681\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask5\",\"eTag\":\"0x8D619B6FABE1828\",\"lastModified\":\"2018-09-13T20:25:00.1008168Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask5\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask3\",\"eTag\":\"0x8D619B6FAD2B1C1\",\"lastModified\":\"2018-09-13T20:25:00.2358209Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask3\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask6\",\"eTag\":\"0x8D619B6FABE1828\",\"lastModified\":\"2018-09-13T20:25:00.1008168Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask6\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask669\",\"eTag\":\"0x8D619B6FAD597EB\",\"lastModified\":\"2018-09-13T20:25:00.2548203Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask669\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask12\",\"eTag\":\"0x8D619B6FACCBE39\",\"lastModified\":\"2018-09-13T20:25:00.1968185Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask12\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask7\",\"eTag\":\"0x8D619B6FABC9175\",\"lastModified\":\"2018-09-13T20:25:00.0908149Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask7\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask666\",\"eTag\":\"0x8D619B6FADAC803\",\"lastModified\":\"2018-09-13T20:25:00.2888195Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask666\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask1\",\"eTag\":\"0x8D619B6FACF3AE0\",\"lastModified\":\"2018-09-13T20:25:00.2131168Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask1\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask674\",\"eTag\":\"0x8D619B6FADCC45F\",\"lastModified\":\"2018-09-13T20:25:00.3018335Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask674\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask682\",\"eTag\":\"0x8D619B6FACE9300\",\"lastModified\":\"2018-09-13T20:25:00.2088192Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask682\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask677\",\"eTag\":\"0x8D619B6FADDD551\",\"lastModified\":\"2018-09-13T20:25:00.3088209Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask677\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask673\",\"eTag\":\"0x8D619B6FADF830E\",\"lastModified\":\"2018-09-13T20:25:00.3198222Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask673\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask670\",\"eTag\":\"0x8D619B6FAD597EB\",\"lastModified\":\"2018-09-13T20:25:00.2548203Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask670\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask672\",\"eTag\":\"0x8D619B6FADE4A83\",\"lastModified\":\"2018-09-13T20:25:00.3118211Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask672\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask4\",\"eTag\":\"0x8D619B6FAD3A3C5\",\"lastModified\":\"2018-09-13T20:25:00.2420165Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask4\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask671\",\"eTag\":\"0x8D619B6FAD68BD7\",\"lastModified\":\"2018-09-13T20:25:00.2610647Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask671\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask668\",\"eTag\":\"0x8D619B6FAD808EE\",\"lastModified\":\"2018-09-13T20:25:00.2708206Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask668\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask667\",\"eTag\":\"0x8D619B6FAD9DDDC\",\"lastModified\":\"2018-09-13T20:25:00.2828252Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask667\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask680\",\"eTag\":\"0x8D619B6FAD9DDDC\",\"lastModified\":\"2018-09-13T20:25:00.2828252Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask680\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask679\",\"eTag\":\"0x8D619B6FADA2BD3\",\"lastModified\":\"2018-09-13T20:25:00.2848211Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask679\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask676\",\"eTag\":\"0x8D619B6FADAEF2F\",\"lastModified\":\"2018-09-13T20:25:00.2898223Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask676\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask678\",\"eTag\":\"0x8D619B6FADA2BD3\",\"lastModified\":\"2018-09-13T20:25:00.2848211Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask678\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask675\",\"eTag\":\"0x8D619B6FADAC803\",\"lastModified\":\"2018-09-13T20:25:00.2888195Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask675\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:24:59 GMT'] + request-id: [e75a7079-cde1-41cd-8df1-0676e4af365f] + server: [Microsoft-HTTPAPI/2.0] + strict-transport-security: [max-age=31536000; includeSubDomains] + transfer-encoding: [chunked] + x-content-type-options: [nosniff] + status: {code: 200, message: OK} +- request: + body: '{"value": [{"id": "mytask665", "commandLine": "sleep 1", "resourceFiles": + [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask664", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask663", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask662", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask661", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask660", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask659", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask658", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask657", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask656", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask655", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask654", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask653", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask652", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask651", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask650", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask649", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask648", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask647", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask646", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask645", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask644", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask643", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask642", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask641", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask640", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask639", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask638", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask637", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask636", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask635", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask634", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}, {"id": "mytask633", "commandLine": "sleep 1", + "resourceFiles": [{"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile0", + "filePath": "resourceFile0"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile1", + "filePath": "resourceFile1"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile2", + "filePath": "resourceFile2"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile3", + "filePath": "resourceFile3"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile4", + "filePath": "resourceFile4"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile5", + "filePath": "resourceFile5"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile6", + "filePath": "resourceFile6"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile7", + "filePath": "resourceFile7"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile8", + "filePath": "resourceFile8"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile9", + "filePath": "resourceFile9"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile10", + "filePath": "resourceFile10"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile11", + "filePath": "resourceFile11"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile12", + "filePath": "resourceFile12"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile13", + "filePath": "resourceFile13"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile14", + "filePath": "resourceFile14"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile15", + "filePath": "resourceFile15"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile16", + "filePath": "resourceFile16"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile17", + "filePath": "resourceFile17"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile18", + "filePath": "resourceFile18"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile19", + "filePath": "resourceFile19"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile20", + "filePath": "resourceFile20"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile21", + "filePath": "resourceFile21"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile22", + "filePath": "resourceFile22"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile23", + "filePath": "resourceFile23"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile24", + "filePath": "resourceFile24"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile25", + "filePath": "resourceFile25"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile26", + "filePath": "resourceFile26"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile27", + "filePath": "resourceFile27"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile28", + "filePath": "resourceFile28"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile29", + "filePath": "resourceFile29"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile30", + "filePath": "resourceFile30"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile31", + "filePath": "resourceFile31"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile32", + "filePath": "resourceFile32"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile33", + "filePath": "resourceFile33"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile34", + "filePath": "resourceFile34"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile35", + "filePath": "resourceFile35"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile36", + "filePath": "resourceFile36"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile37", + "filePath": "resourceFile37"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile38", + "filePath": "resourceFile38"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile39", + "filePath": "resourceFile39"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile40", + "filePath": "resourceFile40"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile41", + "filePath": "resourceFile41"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile42", + "filePath": "resourceFile42"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile43", + "filePath": "resourceFile43"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile44", + "filePath": "resourceFile44"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile45", + "filePath": "resourceFile45"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile46", + "filePath": "resourceFile46"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile47", + "filePath": "resourceFile47"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile48", + "filePath": "resourceFile48"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile49", + "filePath": "resourceFile49"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile50", + "filePath": "resourceFile50"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile51", + "filePath": "resourceFile51"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile52", + "filePath": "resourceFile52"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile53", + "filePath": "resourceFile53"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile54", + "filePath": "resourceFile54"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile55", + "filePath": "resourceFile55"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile56", + "filePath": "resourceFile56"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile57", + "filePath": "resourceFile57"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile58", + "filePath": "resourceFile58"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile59", + "filePath": "resourceFile59"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile60", + "filePath": "resourceFile60"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile61", + "filePath": "resourceFile61"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile62", + "filePath": "resourceFile62"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile63", + "filePath": "resourceFile63"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile64", + "filePath": "resourceFile64"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile65", + "filePath": "resourceFile65"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile66", + "filePath": "resourceFile66"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile67", + "filePath": "resourceFile67"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile68", + "filePath": "resourceFile68"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile69", + "filePath": "resourceFile69"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile70", + "filePath": "resourceFile70"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile71", + "filePath": "resourceFile71"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile72", + "filePath": "resourceFile72"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile73", + "filePath": "resourceFile73"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile74", + "filePath": "resourceFile74"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile75", + "filePath": "resourceFile75"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile76", + "filePath": "resourceFile76"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile77", + "filePath": "resourceFile77"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile78", + "filePath": "resourceFile78"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile79", + "filePath": "resourceFile79"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile80", + "filePath": "resourceFile80"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile81", + "filePath": "resourceFile81"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile82", + "filePath": "resourceFile82"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile83", + "filePath": "resourceFile83"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile84", + "filePath": "resourceFile84"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile85", + "filePath": "resourceFile85"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile86", + "filePath": "resourceFile86"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile87", + "filePath": "resourceFile87"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile88", + "filePath": "resourceFile88"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile89", + "filePath": "resourceFile89"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile90", + "filePath": "resourceFile90"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile91", + "filePath": "resourceFile91"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile92", + "filePath": "resourceFile92"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile93", + "filePath": "resourceFile93"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile94", + "filePath": "resourceFile94"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile95", + "filePath": "resourceFile95"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile96", + "filePath": "resourceFile96"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile97", + "filePath": "resourceFile97"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile98", + "filePath": "resourceFile98"}, {"blobSource": "https://mystorageaccount.blob.core.windows.net/files/resourceFile99", + "filePath": "resourceFile99"}]}]}' + headers: + Accept: [application/json] + Accept-Encoding: ['gzip, deflate'] + Connection: [keep-alive] + Content-Length: ['387629'] + Content-Type: [application/json; odata=minimalmetadata; charset=utf-8] + User-Agent: [python/3.6.5 (Windows-10-10.0.17134-SP0) requests/2.19.1 msrest/0.5.4 + msrest_azure/0.4.34 azure-batch/5.1.0 Azure-SDK-For-Python] + accept-language: [en-US] + ocp-date: ['Thu, 13 Sep 2018 20:25:00 GMT'] + method: POST + uri: https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/addtaskcollection?api-version=2018-08-01.7.0 + response: + body: {string: "{\r\n \"odata.metadata\":\"https://batch98da0af6.eastus.batch.azure.com/$metadata#taskaddresult\",\"value\":[\r\n + \ {\r\n \"status\":\"Success\",\"taskId\":\"mytask665\",\"eTag\":\"0x8D619B6FBAEB25E\",\"lastModified\":\"2018-09-13T20:25:01.6776286Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask665\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask663\",\"eTag\":\"0x8D619B6FBB13D07\",\"lastModified\":\"2018-09-13T20:25:01.6942855Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask663\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask661\",\"eTag\":\"0x8D619B6FBB234EA\",\"lastModified\":\"2018-09-13T20:25:01.7006314Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask661\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask664\",\"eTag\":\"0x8D619B6FBB2A9E7\",\"lastModified\":\"2018-09-13T20:25:01.7036263Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask664\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask662\",\"eTag\":\"0x8D619B6FBB4CD10\",\"lastModified\":\"2018-09-13T20:25:01.7176336Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask662\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask660\",\"eTag\":\"0x8D619B6FBB48630\",\"lastModified\":\"2018-09-13T20:25:01.7158192Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask660\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask659\",\"eTag\":\"0x8D619B6FBB6A1C6\",\"lastModified\":\"2018-09-13T20:25:01.7296326Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask659\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask658\",\"eTag\":\"0x8D619B6FBB6CA20\",\"lastModified\":\"2018-09-13T20:25:01.7306656Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask658\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask657\",\"eTag\":\"0x8D619B6FBB82830\",\"lastModified\":\"2018-09-13T20:25:01.7396272Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask657\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask656\",\"eTag\":\"0x8D619B6FBB988FE\",\"lastModified\":\"2018-09-13T20:25:01.748659Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask656\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask655\",\"eTag\":\"0x8D619B6FBB9AEEB\",\"lastModified\":\"2018-09-13T20:25:01.7496299Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask655\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask654\",\"eTag\":\"0x8D619B6FBBAE89E\",\"lastModified\":\"2018-09-13T20:25:01.7576606Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask654\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask653\",\"eTag\":\"0x8D619B6FBBC6F3D\",\"lastModified\":\"2018-09-13T20:25:01.7676605Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask653\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask651\",\"eTag\":\"0x8D619B6FBBDCE18\",\"lastModified\":\"2018-09-13T20:25:01.7766424Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask651\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask652\",\"eTag\":\"0x8D619B6FBBDCE18\",\"lastModified\":\"2018-09-13T20:25:01.7766424Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask652\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask650\",\"eTag\":\"0x8D619B6FBC0B521\",\"lastModified\":\"2018-09-13T20:25:01.7956641Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask650\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask649\",\"eTag\":\"0x8D619B6FBC0DAE9\",\"lastModified\":\"2018-09-13T20:25:01.7966313Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask649\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask648\",\"eTag\":\"0x8D619B6FBC2147E\",\"lastModified\":\"2018-09-13T20:25:01.804659Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask648\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask647\",\"eTag\":\"0x8D619B6FBC23A7D\",\"lastModified\":\"2018-09-13T20:25:01.8056317Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask647\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask646\",\"eTag\":\"0x8D619B6FBC39A0B\",\"lastModified\":\"2018-09-13T20:25:01.8146315Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask646\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask645\",\"eTag\":\"0x8D619B6FBC4843E\",\"lastModified\":\"2018-09-13T20:25:01.820627Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask645\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask641\",\"eTag\":\"0x8D619B6FBC87C16\",\"lastModified\":\"2018-09-13T20:25:01.8466326Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask641\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask644\",\"eTag\":\"0x8D619B6FBC65DE5\",\"lastModified\":\"2018-09-13T20:25:01.8327525Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask644\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask642\",\"eTag\":\"0x8D619B6FBC7E4E1\",\"lastModified\":\"2018-09-13T20:25:01.8427617Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask642\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask638\",\"eTag\":\"0x8D619B6FBCC2936\",\"lastModified\":\"2018-09-13T20:25:01.8707254Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask638\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask640\",\"eTag\":\"0x8D619B6FBC91848\",\"lastModified\":\"2018-09-13T20:25:01.8506312Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask640\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask637\",\"eTag\":\"0x8D619B6FBCDFA3C\",\"lastModified\":\"2018-09-13T20:25:01.88263Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask637\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask643\",\"eTag\":\"0x8D619B6FBCDAC1A\",\"lastModified\":\"2018-09-13T20:25:01.8806298Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask643\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask639\",\"eTag\":\"0x8D619B6FBCAC5FE\",\"lastModified\":\"2018-09-13T20:25:01.8616318Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask639\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask636\",\"eTag\":\"0x8D619B6FBCF0BB6\",\"lastModified\":\"2018-09-13T20:25:01.889631Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask636\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask635\",\"eTag\":\"0x8D619B6FBCF32B4\",\"lastModified\":\"2018-09-13T20:25:01.8906292Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask635\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask634\",\"eTag\":\"0x8D619B6FBD06C3B\",\"lastModified\":\"2018-09-13T20:25:01.8986555Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask634\"\r\n + \ },{\r\n \"status\":\"Success\",\"taskId\":\"mytask633\",\"eTag\":\"0x8D619B6FBD0E0B5\",\"lastModified\":\"2018-09-13T20:25:01.9016373Z\",\"location\":\"https://batch98da0af6.eastus.batch.azure.com/jobs/batch98da0af6/tasks/mytask633\"\r\n + \ }\r\n ]\r\n}"} + headers: + content-type: [application/json;odata=minimalmetadata] + dataserviceversion: ['3.0'] + date: ['Thu, 13 Sep 2018 20:25:01 GMT'] + request-id: [174a7df4-baa7-4e8e-bb1f-22c28c988cf9] server: [Microsoft-HTTPAPI/2.0] strict-transport-security: [max-age=31536000; includeSubDomains] transfer-encoding: [chunked] diff --git a/azure-batch/tests/test_batch.py b/azure-batch/tests/test_batch.py index d2bedc8a0347..2769e766a140 100644 --- a/azure-batch/tests/test_batch.py +++ b/azure-batch/tests/test_batch.py @@ -10,11 +10,11 @@ import logging import time import unittest - import requests import azure.batch from azure.batch import models + from batch_preparers import ( AccountPreparer, PoolPreparer, @@ -75,6 +75,20 @@ def assertBatchError(self, code, func, *args, **kwargs): except Exception as err: self.fail("Expected BatchErrorExcption, instead got: {!r}".format(err)) + def assertCreateTasksError(self, code, func, *args, **kwargs): + try: + func(*args, **kwargs) + self.fail("CreateTasksError expected but not raised") + except models.CreateTasksErrorException as err: + try: + batch_error = err.errors.pop() + if code: + self.assertEqual(batch_error.error.code, code) + except IndexError: + self.fail("Inner BatchErrorException expected but not exist") + except Exception as err: + self.fail("Expected CreateTasksError, instead got: {!r}".format(err)) + @ResourceGroupPreparer(location=AZURE_LOCATION) @StorageAccountPreparer(name_prefix='batch1', location=AZURE_LOCATION) @AccountPreparer(location=AZURE_LOCATION) @@ -868,7 +882,7 @@ def test_batch_tasks(self, batch_job, **kwargs): constraints=models.TaskConstraints(max_task_retry_count=1)) self.assertIsNone(response) - # Test Get Subtasks + # Test Get Subtasks # TODO: Test with actual subtasks subtasks = client.task.list_subtasks(batch_job.id, task_param.id) self.assertIsInstance(subtasks, models.CloudTaskListSubtasksResult) @@ -878,6 +892,48 @@ def test_batch_tasks(self, batch_job, **kwargs): response = client.task.delete(batch_job.id, task_param.id) self.assertIsNone(response) + # Test Bulk Add Task Failure + task_id = "mytask" + tasks_to_add = [] + resource_files = [] + for i in range(10000): + resource_file = models.ResourceFile( + blob_source="https://mystorageaccount.blob.core.windows.net/files/resourceFile{}".format(str(i)), + file_path="resourceFile{}".format(str(i))) + resource_files.append(resource_file) + task = models.TaskAddParameter( + id=task_id, + command_line="sleep 1", + resource_files=resource_files) + tasks_to_add.append(task) + self.assertCreateTasksError( + "RequestBodyTooLarge", + client.task.add_collection, + batch_job.id, + tasks_to_add) + + # Test Bulk Add Task Success + task_id = "mytask" + tasks_to_add = [] + resource_files = [] + for i in range(100): + resource_file = models.ResourceFile( + blob_source="https://mystorageaccount.blob.core.windows.net/files/resourceFile" + str(i), + file_path="resourceFile"+str(i)) + resource_files.append(resource_file) + for i in range(733): + task = models.TaskAddParameter( + id=task_id + str(i), + command_line="sleep 1", + resource_files=resource_files) + tasks_to_add.append(task) + result = client.task.add_collection(batch_job.id, tasks_to_add) + self.assertIsInstance(result, models.TaskAddCollectionResult) + self.assertEqual(len(result.value), 733) + self.assertEqual(result.value[0].status, models.TaskAddStatus.success) + self.assertTrue( + all(t.status == models.TaskAddStatus.success for t in result.value)) + @ResourceGroupPreparer(location=AZURE_LOCATION) @AccountPreparer(location=AZURE_LOCATION) def test_batch_jobs(self, **kwargs):